handler) {
+ return null;
+ }
+
+ @Override
+ public boolean reset(long code) {
+ return false;
+ }
+
+ @Override
+ public boolean reset(long code, Throwable cause) {
+ return false;
+ }
+
+ @Override
+ public HttpConnection connection() {
+ return null;
+ }
+
+ @Override
+ public HttpClientRequest writeCustomFrame(int type, int flags, Buffer payload) {
+ return null;
+ }
+
+ @Override
+ public StreamPriority getStreamPriority() {
+ return null;
+ }
+}
diff --git a/sdk/core/azure-core-http-vertx/src/test/java/com/azure/core/http/vertx/implementation/VertxRequestWriteSubscriberTests.java b/sdk/core/azure-core-http-vertx/src/test/java/com/azure/core/http/vertx/implementation/VertxRequestWriteSubscriberTests.java
new file mode 100644
index 000000000000..39a27a8e5cc6
--- /dev/null
+++ b/sdk/core/azure-core-http-vertx/src/test/java/com/azure/core/http/vertx/implementation/VertxRequestWriteSubscriberTests.java
@@ -0,0 +1,249 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+package com.azure.core.http.vertx.implementation;
+
+import com.azure.core.http.HttpResponse;
+import com.azure.core.util.SharedExecutorService;
+import io.vertx.core.AsyncResult;
+import io.vertx.core.Future;
+import io.vertx.core.Handler;
+import io.vertx.core.Promise;
+import io.vertx.core.buffer.Buffer;
+import io.vertx.core.http.HttpClientRequest;
+import org.junit.jupiter.api.Test;
+import reactor.core.publisher.Flux;
+import reactor.util.context.Context;
+
+import java.nio.ByteBuffer;
+import java.nio.charset.StandardCharsets;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicReference;
+import java.util.function.Consumer;
+
+import static com.azure.core.validation.http.HttpValidatonUtils.assertArraysEqual;
+import static org.junit.jupiter.api.Assertions.assertEquals;
+import static org.junit.jupiter.api.Assertions.assertNull;
+import static org.junit.jupiter.api.Assertions.assertSame;
+import static org.junit.jupiter.api.Assertions.assertTrue;
+import static org.junit.jupiter.api.Assertions.fail;
+
+/**
+ * Tests the functionality of {@link VertxRequestWriteSubscriber}.
+ */
+public class VertxRequestWriteSubscriberTests {
+ private static final byte[] DATA = "Hello, world!".getBytes(StandardCharsets.UTF_8);
+
+ /**
+ * Tests that request writing operates as expected when the reactive stream has onNext followed by onError.
+ *
+ * The result of this operation order should be that the request is failed.
+ */
+ @Test
+ public void onNextThenOnErrorInSuccession() throws InterruptedException {
+ RuntimeException reactiveError = new RuntimeException("Reactive error");
+ AtomicReference onErrorDropped = new AtomicReference<>();
+ Consumer onErrorDroppedConsumer = onErrorDropped::set;
+
+ Flux data = Flux.generate(sink -> {
+ sink.next(ByteBuffer.wrap(DATA));
+ sink.error(reactiveError);
+ });
+
+ Promise promise = Promise.promise();
+ Buffer writtenContent = Buffer.buffer();
+ HttpClientRequest httpClientRequest = new MockHttpClientRequest() {
+ @Override
+ public void write(Buffer data, Handler> handler) {
+ writtenContent.appendBuffer(data);
+ Promise promise = Promise.promise();
+ promise.future().onComplete(handler);
+ promise.complete();
+ }
+ };
+
+ VertxRequestWriteSubscriber subscriber = new VertxRequestWriteSubscriber(httpClientRequest, promise, null,
+ Context.of("reactor.onErrorDropped.local", onErrorDroppedConsumer));
+
+ data.subscribe(subscriber);
+
+ waitForCompletion(promise);
+ assertTrue(promise.future().failed(), "The request should have failed.");
+ assertSame(reactiveError, promise.future().cause());
+ assertNull(onErrorDropped.get(), "No reactive error should be dropped.");
+ assertArraysEqual(DATA, writtenContent.getBytes());
+ }
+
+ /**
+ * Tests that request writing operates as expected when the reactive stream has onNext followed by onError.
+ *
+ * The result of this operation order should be that the request is failed and there is an error dropped. An error
+ * should be dropped as the error with the write failure should occur first.
+ */
+ @Test
+ public void onNextWithWriteFailureThenOnError() throws InterruptedException {
+ RuntimeException writeError = new RuntimeException("Write error");
+ RuntimeException reactiveError = new RuntimeException("Reactive error");
+ AtomicReference onErrorDropped = new AtomicReference<>();
+ Consumer onErrorDroppedConsumer = onErrorDropped::set;
+
+ Flux data = Flux.generate(sink -> {
+ sink.next(ByteBuffer.wrap(DATA));
+ sink.error(reactiveError);
+ });
+
+ Promise promise = Promise.promise();
+ HttpClientRequest httpClientRequest = new MockHttpClientRequest() {
+ @Override
+ public void write(Buffer data, Handler> handler) {
+ Promise promise = Promise.promise();
+ promise.future().onComplete(handler);
+ promise.fail(writeError);
+ }
+ };
+
+ VertxRequestWriteSubscriber subscriber = new VertxRequestWriteSubscriber(httpClientRequest, promise, null,
+ Context.of("reactor.onErrorDropped.local", onErrorDroppedConsumer));
+
+ data.subscribe(subscriber);
+
+ waitForCompletion(promise);
+ assertTrue(promise.future().failed(), "The request should have failed.");
+ assertSame(writeError, promise.future().cause(), "The write error should be the cause of the failure.");
+ assertSame(reactiveError, onErrorDropped.get(), "The reactive error should be dropped.");
+ }
+
+ /**
+ * Tests that request writing operates as expected when the reactive stream has onNext followed by onComplete.
+ *
+ * The result of this operation order should be that the request is successful. The onNext signal should be
+ * processed and content written then the request should be completed due to the onComplete signal.
+ */
+ @Test
+ public void onNextThenOnCompleteInSuccession() throws InterruptedException {
+ Promise promise = Promise.promise();
+ Flux data = Flux.generate(sink -> {
+ sink.next(ByteBuffer.wrap(DATA));
+ sink.complete();
+ });
+ Buffer writtenContent = Buffer.buffer();
+ HttpClientRequest httpClientRequest = new MockHttpClientRequest() {
+ @Override
+ public void write(Buffer data, Handler> handler) {
+ writtenContent.appendBuffer(data);
+ Promise promise = Promise.promise();
+ promise.future().onComplete(handler);
+ promise.complete();
+ }
+
+ @Override
+ public Future end() {
+ promise.complete();
+ return super.end();
+ }
+ };
+
+ VertxRequestWriteSubscriber subscriber
+ = new VertxRequestWriteSubscriber(httpClientRequest, promise, null, Context.empty());
+
+ data.subscribe(subscriber);
+
+ waitForCompletion(promise);
+ assertTrue(promise.future().succeeded(), "The request should have succeeded.");
+ assertArraysEqual(DATA, writtenContent.getBytes());
+ }
+
+ /**
+ * Tests that request writing operates as expected when the reactive stream has onNext followed by onComplete.
+ *
+ * The result of this operation order should be that the request is failed and there are no errors dropped. While
+ * the reactive stream completed successfully the writing of the request failed.
+ */
+ @Test
+ public void onNextWithWriteFailureThenOnComplete() throws InterruptedException {
+ RuntimeException writeError = new RuntimeException("Write error");
+ AtomicReference onErrorDropped = new AtomicReference<>();
+ Consumer onErrorDroppedConsumer = onErrorDropped::set;
+ Promise promise = Promise.promise();
+ Flux data = Flux.generate(sink -> {
+ sink.next(ByteBuffer.wrap(DATA));
+ sink.complete();
+ });
+ HttpClientRequest httpClientRequest = new MockHttpClientRequest() {
+ @Override
+ public void write(Buffer data, Handler> handler) {
+ Promise promise = Promise.promise();
+ promise.future().onComplete(handler);
+ promise.fail(writeError);
+ }
+ };
+
+ VertxRequestWriteSubscriber subscriber = new VertxRequestWriteSubscriber(httpClientRequest, promise, null,
+ Context.of("reactor.onErrorDropped.local", onErrorDroppedConsumer));
+
+ data.subscribe(subscriber);
+
+ waitForCompletion(promise);
+ assertTrue(promise.future().failed(), "The request should have failed.");
+ assertSame(writeError, promise.future().cause(), "The write error should be the cause of the failure.");
+ assertNull(onErrorDropped.get(), "No reactive error should be dropped.");
+ }
+
+ /**
+ * Tests that if the promise being used to manage the request-response state succeeds externally while writing the
+ * request it is handled appropriately.
+ *
+ * The exception(s) that occur during writing should be dropped as the promise doesn't have a failure cause.
+ */
+ @Test
+ public void promiseIsSucceededExternalWhileRequestIsBeingSent() throws InterruptedException {
+ CountDownLatch latch = new CountDownLatch(1);
+ RuntimeException writeError = new RuntimeException("Write error");
+ RuntimeException reactiveError = new RuntimeException("Reactive error");
+ AtomicReference onErrorDropped = new AtomicReference<>();
+ Consumer onErrorDroppedConsumer = onErrorDropped::set;
+ Promise promise = Promise.promise();
+ Flux data = Flux.generate(sink -> {
+ sink.next(ByteBuffer.wrap(DATA));
+ sink.error(reactiveError);
+ });
+ HttpClientRequest httpClientRequest = new MockHttpClientRequest() {
+ @Override
+ public void write(Buffer data, Handler> handler) {
+ SharedExecutorService.getInstance().schedule(() -> {
+ Promise promise = Promise.promise();
+ promise.future().onComplete(handler);
+ promise.fail(writeError);
+ latch.countDown();
+ }, 1000, TimeUnit.MILLISECONDS);
+ }
+ };
+
+ VertxRequestWriteSubscriber subscriber = new VertxRequestWriteSubscriber(httpClientRequest, promise, null,
+ Context.of("reactor.onErrorDropped.local", onErrorDroppedConsumer));
+
+ data.subscribe(subscriber);
+ promise.complete();
+
+ if (!latch.await(5, TimeUnit.SECONDS)) {
+ fail("Timed out waiting for the request to be written.");
+ }
+
+ assertTrue(promise.future().succeeded(), "The request should have succeeded.");
+ assertEquals(writeError, onErrorDropped.get(), "The write error should be dropped.");
+ Throwable[] writeSuppressed = writeError.getSuppressed();
+ assertEquals(1, writeSuppressed.length, "There should be one suppressed exception.");
+ assertSame(reactiveError, writeSuppressed[0], "The reactive error should be the suppressed exception.");
+ }
+
+ private static void waitForCompletion(Promise> promise) throws InterruptedException {
+ for (int i = 0; i < 5; i++) {
+ Thread.sleep(1000);
+ if (promise.future().isComplete()) {
+ return;
+ }
+ }
+
+ fail("Timed out waiting for test to complete.");
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/CHANGELOG.md b/sdk/datafactory/azure-resourcemanager-datafactory/CHANGELOG.md
index 735dd6a5a4de..0c63f05f09e0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/CHANGELOG.md
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/CHANGELOG.md
@@ -1,6 +1,6 @@
# Release History
-## 1.0.0-beta.31 (Unreleased)
+## 1.1.0-beta.1 (Unreleased)
### Features Added
@@ -10,6 +10,156 @@
### Other Changes
+## 1.0.0 (2024-12-16)
+
+- Azure Resource Manager DataFactory client library for Java. This package contains Microsoft Azure SDK for DataFactory Management SDK. The Azure Data Factory V2 management API provides a RESTful set of web services that interact with Azure Data Factory V2 services. Package tag package-2018-06. For documentation on how to use this package, please see [Azure Management Libraries for Java](https://aka.ms/azsdk/java/mgmt).
+
+### Breaking Changes
+
+#### `models.Expression` was modified
+
+* `withType(java.lang.String)` was removed
+
+#### `models.TumblingWindowTrigger` was modified
+
+* `runtimeState()` was removed
+
+#### `models.DatasetReference` was modified
+
+* `withType(java.lang.String)` was removed
+
+#### `models.CustomEventsTrigger` was modified
+
+* `runtimeState()` was removed
+
+#### `models.IntegrationRuntimeReference` was modified
+
+* `withType(java.lang.String)` was removed
+
+#### `models.MultiplePipelineTrigger` was modified
+
+* `runtimeState()` was removed
+
+#### `models.RerunTumblingWindowTrigger` was modified
+
+* `runtimeState()` was removed
+
+#### `models.ScheduleTrigger` was modified
+
+* `runtimeState()` was removed
+
+#### `models.LinkedServiceReference` was modified
+
+* `withType(java.lang.String)` was removed
+
+#### `models.PipelineReference` was modified
+
+* `withType(java.lang.String)` was removed
+
+#### `models.BlobEventsTrigger` was modified
+
+* `runtimeState()` was removed
+
+#### `models.BlobTrigger` was modified
+
+* `runtimeState()` was removed
+
+#### `models.SelfHostedIntegrationRuntimeStatus` was modified
+
+* `dataFactoryName()` was removed
+* `state()` was removed
+
+#### `models.ManagedIntegrationRuntimeStatus` was modified
+
+* `dataFactoryName()` was removed
+* `state()` was removed
+
+#### `models.ChainingTrigger` was modified
+
+* `runtimeState()` was removed
+
+### Features Added
+
+* `models.IcebergSink` was added
+
+* `models.IcebergDataset` was added
+
+* `models.IcebergWriteSettings` was added
+
+#### `models.ScriptActivity` was modified
+
+* `returnMultistatementResult()` was added
+* `withReturnMultistatementResult(java.lang.Object)` was added
+
+#### `models.SalesforceV2Source` was modified
+
+* `pageSize()` was added
+* `withPageSize(java.lang.Object)` was added
+
+#### `models.MariaDBLinkedService` was modified
+
+* `withUseSystemTrustStore(java.lang.Object)` was added
+* `withSslMode(java.lang.Object)` was added
+* `useSystemTrustStore()` was added
+* `sslMode()` was added
+
+#### `models.ServiceNowV2Source` was modified
+
+* `pageSize()` was added
+* `withPageSize(java.lang.Object)` was added
+
+#### `models.SnowflakeV2LinkedService` was modified
+
+* `withHost(java.lang.Object)` was added
+* `host()` was added
+
+#### `models.AzurePostgreSqlLinkedService` was modified
+
+* `withEncoding(java.lang.Object)` was added
+* `withPort(java.lang.Object)` was added
+* `timeout()` was added
+* `server()` was added
+* `sslMode()` was added
+* `encoding()` was added
+* `withCommandTimeout(java.lang.Object)` was added
+* `withTimezone(java.lang.Object)` was added
+* `withTrustServerCertificate(java.lang.Object)` was added
+* `trustServerCertificate()` was added
+* `withServer(java.lang.Object)` was added
+* `timezone()` was added
+* `username()` was added
+* `commandTimeout()` was added
+* `withDatabase(java.lang.Object)` was added
+* `withSslMode(java.lang.Object)` was added
+* `withTimeout(java.lang.Object)` was added
+* `database()` was added
+* `readBufferSize()` was added
+* `port()` was added
+* `withReadBufferSize(java.lang.Object)` was added
+* `withUsername(java.lang.Object)` was added
+
+#### `models.PostgreSqlV2LinkedService` was modified
+
+* `withAuthenticationType(java.lang.Object)` was added
+* `authenticationType()` was added
+
+#### `models.MySqlLinkedService` was modified
+
+* `connectionTimeout()` was added
+* `withSslKey(java.lang.Object)` was added
+* `treatTinyAsBoolean()` was added
+* `sslCert()` was added
+* `withSslCert(java.lang.Object)` was added
+* `withTreatTinyAsBoolean(java.lang.Object)` was added
+* `convertZeroDateTime()` was added
+* `withGuidFormat(java.lang.Object)` was added
+* `allowZeroDateTime()` was added
+* `sslKey()` was added
+* `guidFormat()` was added
+* `withAllowZeroDateTime(java.lang.Object)` was added
+* `withConnectionTimeout(java.lang.Object)` was added
+* `withConvertZeroDateTime(java.lang.Object)` was added
+
## 1.0.0-beta.30 (2024-08-21)
- Azure Resource Manager DataFactory client library for Java. This package contains Microsoft Azure SDK for DataFactory Management SDK. The Azure Data Factory V2 management API provides a RESTful set of web services that interact with Azure Data Factory V2 services. Package tag package-2018-06. For documentation on how to use this package, please see [Azure Management Libraries for Java](https://aka.ms/azsdk/java/mgmt).
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/README.md b/sdk/datafactory/azure-resourcemanager-datafactory/README.md
index afff5f187a48..3325d497a2c8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/README.md
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/README.md
@@ -32,7 +32,7 @@ Various documentation is available to help you get started
com.azure.resourcemanager
azure-resourcemanager-datafactory
- 1.0.0-beta.30
+ 1.0.0
```
[//]: # ({x-version-update-end})
@@ -72,30 +72,33 @@ See [API design][design] for general introduction on design and key concepts on
```java
// storage account
-StorageAccount storageAccount = storageManager.storageAccounts().define(STORAGE_ACCOUNT)
+StorageAccount storageAccount = storageManager.storageAccounts()
+ .define(STORAGE_ACCOUNT)
.withRegion(REGION)
.withExistingResourceGroup(resourceGroup)
.create();
final String storageAccountKey = storageAccount.getKeys().iterator().next().value();
-final String connectionString = getStorageConnectionString(STORAGE_ACCOUNT, storageAccountKey, storageManager.environment());
+final String connectionString
+ = getStorageConnectionString(STORAGE_ACCOUNT, storageAccountKey, storageManager.environment());
// container
final String containerName = "adf";
-storageManager.blobContainers().defineContainer(containerName)
+storageManager.blobContainers()
+ .defineContainer(containerName)
.withExistingStorageAccount(resourceGroup, STORAGE_ACCOUNT)
.withPublicAccess(PublicAccess.NONE)
.create();
// blob as input
-BlobClient blobClient = new BlobClientBuilder()
- .connectionString(connectionString)
+BlobClient blobClient = new BlobClientBuilder().connectionString(connectionString)
.containerName(containerName)
.blobName("input/data.txt")
.buildClient();
blobClient.upload(BinaryData.fromString("data"));
// data factory
-Factory dataFactory = manager.factories().define(DATA_FACTORY)
+Factory dataFactory = manager.factories()
+ .define(DATA_FACTORY)
.withRegion(REGION)
.withExistingResourceGroup(resourceGroup)
.create();
@@ -106,15 +109,16 @@ connectionStringProperty.put("type", "SecureString");
connectionStringProperty.put("value", connectionString);
final String linkedServiceName = "LinkedService";
-manager.linkedServices().define(linkedServiceName)
+manager.linkedServices()
+ .define(linkedServiceName)
.withExistingFactory(resourceGroup, DATA_FACTORY)
- .withProperties(new AzureStorageLinkedService()
- .withConnectionString(connectionStringProperty))
+ .withProperties(new AzureStorageLinkedService().withConnectionString(connectionStringProperty))
.create();
// input dataset
final String inputDatasetName = "InputDataset";
-manager.datasets().define(inputDatasetName)
+manager.datasets()
+ .define(inputDatasetName)
.withExistingFactory(resourceGroup, DATA_FACTORY)
.withProperties(new AzureBlobDataset()
.withLinkedServiceName(new LinkedServiceReference().withReferenceName(linkedServiceName))
@@ -125,7 +129,8 @@ manager.datasets().define(inputDatasetName)
// output dataset
final String outputDatasetName = "OutputDataset";
-manager.datasets().define(outputDatasetName)
+manager.datasets()
+ .define(outputDatasetName)
.withExistingFactory(resourceGroup, DATA_FACTORY)
.withProperties(new AzureBlobDataset()
.withLinkedServiceName(new LinkedServiceReference().withReferenceName(linkedServiceName))
@@ -135,14 +140,15 @@ manager.datasets().define(outputDatasetName)
.create();
// pipeline
-PipelineResource pipeline = manager.pipelines().define("CopyBlobPipeline")
+PipelineResource pipeline = manager.pipelines()
+ .define("CopyBlobPipeline")
.withExistingFactory(resourceGroup, DATA_FACTORY)
- .withActivities(Collections.singletonList(new CopyActivity()
- .withName("CopyBlob")
+ .withActivities(Collections.singletonList(new CopyActivity().withName("CopyBlob")
.withSource(new BlobSource())
.withSink(new BlobSink())
.withInputs(Collections.singletonList(new DatasetReference().withReferenceName(inputDatasetName)))
- .withOutputs(Collections.singletonList(new DatasetReference().withReferenceName(outputDatasetName)))))
+ .withOutputs(
+ Collections.singletonList(new DatasetReference().withReferenceName(outputDatasetName)))))
.create();
// run pipeline
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/pom.xml b/sdk/datafactory/azure-resourcemanager-datafactory/pom.xml
index 714cfdb34332..70f07e580dd4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/pom.xml
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/pom.xml
@@ -14,7 +14,7 @@
com.azure.resourcemanager
azure-resourcemanager-datafactory
- 1.0.0-beta.31
+ 1.1.0-beta.1
jar
Microsoft Azure SDK for DataFactory Management
@@ -45,14 +45,9 @@
UTF-8
0
0
- true
+ false
-
- com.azure
- azure-json
- 1.3.0
-
com.azure
azure-core
@@ -75,6 +70,11 @@
1.14.2
test
+
+ com.azure
+ azure-json
+ 1.3.0
+
com.azure.resourcemanager
azure-resourcemanager-storage
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/DataFactoryManager.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/DataFactoryManager.java
index 81e28abacde1..38e432f1bf78 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/DataFactoryManager.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/DataFactoryManager.java
@@ -11,15 +11,15 @@
import com.azure.core.http.HttpPipelinePosition;
import com.azure.core.http.policy.AddDatePolicy;
import com.azure.core.http.policy.AddHeadersFromContextPolicy;
-import com.azure.core.http.policy.HttpLoggingPolicy;
+import com.azure.core.http.policy.BearerTokenAuthenticationPolicy;
import com.azure.core.http.policy.HttpLogOptions;
+import com.azure.core.http.policy.HttpLoggingPolicy;
import com.azure.core.http.policy.HttpPipelinePolicy;
import com.azure.core.http.policy.HttpPolicyProviders;
import com.azure.core.http.policy.RequestIdPolicy;
import com.azure.core.http.policy.RetryOptions;
import com.azure.core.http.policy.RetryPolicy;
import com.azure.core.http.policy.UserAgentPolicy;
-import com.azure.core.management.http.policy.ArmChallengeAuthenticationPolicy;
import com.azure.core.management.profile.AzureProfile;
import com.azure.core.util.Configuration;
import com.azure.core.util.logging.ClientLogger;
@@ -43,8 +43,8 @@
import com.azure.resourcemanager.datafactory.implementation.OperationsImpl;
import com.azure.resourcemanager.datafactory.implementation.PipelineRunsImpl;
import com.azure.resourcemanager.datafactory.implementation.PipelinesImpl;
-import com.azure.resourcemanager.datafactory.implementation.PrivateEndpointConnectionOperationsImpl;
import com.azure.resourcemanager.datafactory.implementation.PrivateEndPointConnectionsImpl;
+import com.azure.resourcemanager.datafactory.implementation.PrivateEndpointConnectionOperationsImpl;
import com.azure.resourcemanager.datafactory.implementation.PrivateLinkResourcesImpl;
import com.azure.resourcemanager.datafactory.implementation.TriggerRunsImpl;
import com.azure.resourcemanager.datafactory.implementation.TriggersImpl;
@@ -66,8 +66,8 @@
import com.azure.resourcemanager.datafactory.models.Operations;
import com.azure.resourcemanager.datafactory.models.PipelineRuns;
import com.azure.resourcemanager.datafactory.models.Pipelines;
-import com.azure.resourcemanager.datafactory.models.PrivateEndpointConnectionOperations;
import com.azure.resourcemanager.datafactory.models.PrivateEndPointConnections;
+import com.azure.resourcemanager.datafactory.models.PrivateEndpointConnectionOperations;
import com.azure.resourcemanager.datafactory.models.PrivateLinkResources;
import com.azure.resourcemanager.datafactory.models.TriggerRuns;
import com.azure.resourcemanager.datafactory.models.Triggers;
@@ -294,7 +294,7 @@ public DataFactoryManager authenticate(TokenCredential credential, AzureProfile
.append("-")
.append("com.azure.resourcemanager.datafactory")
.append("/")
- .append("1.0.0-beta.30");
+ .append("1.0.0");
if (!Configuration.getGlobalConfiguration().get("AZURE_TELEMETRY_DISABLED", false)) {
userAgentBuilder.append(" (")
.append(Configuration.getGlobalConfiguration().get("java.version"))
@@ -327,7 +327,7 @@ public DataFactoryManager authenticate(TokenCredential credential, AzureProfile
HttpPolicyProviders.addBeforeRetryPolicies(policies);
policies.add(retryPolicy);
policies.add(new AddDatePolicy());
- policies.add(new ArmChallengeAuthenticationPolicy(credential, scopes.toArray(new String[0])));
+ policies.add(new BearerTokenAuthenticationPolicy(credential, scopes.toArray(new String[0])));
policies.addAll(this.policies.stream()
.filter(p -> p.getPipelinePosition() == HttpPipelinePosition.PER_RETRY)
.collect(Collectors.toList()));
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AmazonRdsForSqlServerLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AmazonRdsForSqlServerLinkedServiceTypeProperties.java
index 3f69aa1cc079..afe99cf6139b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AmazonRdsForSqlServerLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AmazonRdsForSqlServerLinkedServiceTypeProperties.java
@@ -363,7 +363,6 @@ public AmazonRdsForSqlServerLinkedServiceTypeProperties withPooling(Object pooli
*/
@Override
public void validate() {
- super.validate();
if (password() != null) {
password().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzurePostgreSqlLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzurePostgreSqlLinkedServiceTypeProperties.java
index fd1991ac18d9..6855193b6443 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzurePostgreSqlLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzurePostgreSqlLinkedServiceTypeProperties.java
@@ -23,6 +23,65 @@ public final class AzurePostgreSqlLinkedServiceTypeProperties
*/
private Object connectionString;
+ /*
+ * Server name for connection. Type: string.
+ */
+ private Object server;
+
+ /*
+ * The port for the connection. Type: integer.
+ */
+ private Object port;
+
+ /*
+ * Username for authentication. Type: string.
+ */
+ private Object username;
+
+ /*
+ * Database name for connection. Type: string.
+ */
+ private Object database;
+
+ /*
+ * SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4: verify-ca, 5: verify-full.
+ * Type: integer.
+ */
+ private Object sslMode;
+
+ /*
+ * The time to wait (in seconds) while trying to establish a connection before terminating the attempt and
+ * generating an error. Type: integer.
+ */
+ private Object timeout;
+
+ /*
+ * The time to wait (in seconds) while trying to execute a command before terminating the attempt and generating an
+ * error. Set to zero for infinity. Type: integer.
+ */
+ private Object commandTimeout;
+
+ /*
+ * Whether to trust the server certificate without validating it. Type: boolean.
+ */
+ private Object trustServerCertificate;
+
+ /*
+ * Determines the size of the internal buffer uses when reading. Increasing may improve performance if transferring
+ * large values from the database. Type: integer.
+ */
+ private Object readBufferSize;
+
+ /*
+ * Gets or sets the session timezone. Type: string.
+ */
+ private Object timezone;
+
+ /*
+ * Gets or sets the .NET encoding that will be used to encode/decode PostgreSQL string data. Type: string
+ */
+ private Object encoding;
+
/*
* The Azure key vault secret reference of password in connection string.
*/
@@ -62,6 +121,238 @@ public AzurePostgreSqlLinkedServiceTypeProperties withConnectionString(Object co
return this;
}
+ /**
+ * Get the server property: Server name for connection. Type: string.
+ *
+ * @return the server value.
+ */
+ public Object server() {
+ return this.server;
+ }
+
+ /**
+ * Set the server property: Server name for connection. Type: string.
+ *
+ * @param server the server value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withServer(Object server) {
+ this.server = server;
+ return this;
+ }
+
+ /**
+ * Get the port property: The port for the connection. Type: integer.
+ *
+ * @return the port value.
+ */
+ public Object port() {
+ return this.port;
+ }
+
+ /**
+ * Set the port property: The port for the connection. Type: integer.
+ *
+ * @param port the port value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withPort(Object port) {
+ this.port = port;
+ return this;
+ }
+
+ /**
+ * Get the username property: Username for authentication. Type: string.
+ *
+ * @return the username value.
+ */
+ public Object username() {
+ return this.username;
+ }
+
+ /**
+ * Set the username property: Username for authentication. Type: string.
+ *
+ * @param username the username value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withUsername(Object username) {
+ this.username = username;
+ return this;
+ }
+
+ /**
+ * Get the database property: Database name for connection. Type: string.
+ *
+ * @return the database value.
+ */
+ public Object database() {
+ return this.database;
+ }
+
+ /**
+ * Set the database property: Database name for connection. Type: string.
+ *
+ * @param database the database value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withDatabase(Object database) {
+ this.database = database;
+ return this;
+ }
+
+ /**
+ * Get the sslMode property: SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4:
+ * verify-ca, 5: verify-full. Type: integer.
+ *
+ * @return the sslMode value.
+ */
+ public Object sslMode() {
+ return this.sslMode;
+ }
+
+ /**
+ * Set the sslMode property: SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4:
+ * verify-ca, 5: verify-full. Type: integer.
+ *
+ * @param sslMode the sslMode value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withSslMode(Object sslMode) {
+ this.sslMode = sslMode;
+ return this;
+ }
+
+ /**
+ * Get the timeout property: The time to wait (in seconds) while trying to establish a connection before terminating
+ * the attempt and generating an error. Type: integer.
+ *
+ * @return the timeout value.
+ */
+ public Object timeout() {
+ return this.timeout;
+ }
+
+ /**
+ * Set the timeout property: The time to wait (in seconds) while trying to establish a connection before terminating
+ * the attempt and generating an error. Type: integer.
+ *
+ * @param timeout the timeout value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withTimeout(Object timeout) {
+ this.timeout = timeout;
+ return this;
+ }
+
+ /**
+ * Get the commandTimeout property: The time to wait (in seconds) while trying to execute a command before
+ * terminating the attempt and generating an error. Set to zero for infinity. Type: integer.
+ *
+ * @return the commandTimeout value.
+ */
+ public Object commandTimeout() {
+ return this.commandTimeout;
+ }
+
+ /**
+ * Set the commandTimeout property: The time to wait (in seconds) while trying to execute a command before
+ * terminating the attempt and generating an error. Set to zero for infinity. Type: integer.
+ *
+ * @param commandTimeout the commandTimeout value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withCommandTimeout(Object commandTimeout) {
+ this.commandTimeout = commandTimeout;
+ return this;
+ }
+
+ /**
+ * Get the trustServerCertificate property: Whether to trust the server certificate without validating it. Type:
+ * boolean.
+ *
+ * @return the trustServerCertificate value.
+ */
+ public Object trustServerCertificate() {
+ return this.trustServerCertificate;
+ }
+
+ /**
+ * Set the trustServerCertificate property: Whether to trust the server certificate without validating it. Type:
+ * boolean.
+ *
+ * @param trustServerCertificate the trustServerCertificate value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withTrustServerCertificate(Object trustServerCertificate) {
+ this.trustServerCertificate = trustServerCertificate;
+ return this;
+ }
+
+ /**
+ * Get the readBufferSize property: Determines the size of the internal buffer uses when reading. Increasing may
+ * improve performance if transferring large values from the database. Type: integer.
+ *
+ * @return the readBufferSize value.
+ */
+ public Object readBufferSize() {
+ return this.readBufferSize;
+ }
+
+ /**
+ * Set the readBufferSize property: Determines the size of the internal buffer uses when reading. Increasing may
+ * improve performance if transferring large values from the database. Type: integer.
+ *
+ * @param readBufferSize the readBufferSize value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withReadBufferSize(Object readBufferSize) {
+ this.readBufferSize = readBufferSize;
+ return this;
+ }
+
+ /**
+ * Get the timezone property: Gets or sets the session timezone. Type: string.
+ *
+ * @return the timezone value.
+ */
+ public Object timezone() {
+ return this.timezone;
+ }
+
+ /**
+ * Set the timezone property: Gets or sets the session timezone. Type: string.
+ *
+ * @param timezone the timezone value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withTimezone(Object timezone) {
+ this.timezone = timezone;
+ return this;
+ }
+
+ /**
+ * Get the encoding property: Gets or sets the .NET encoding that will be used to encode/decode PostgreSQL string
+ * data. Type: string.
+ *
+ * @return the encoding value.
+ */
+ public Object encoding() {
+ return this.encoding;
+ }
+
+ /**
+ * Set the encoding property: Gets or sets the .NET encoding that will be used to encode/decode PostgreSQL string
+ * data. Type: string.
+ *
+ * @param encoding the encoding value to set.
+ * @return the AzurePostgreSqlLinkedServiceTypeProperties object itself.
+ */
+ public AzurePostgreSqlLinkedServiceTypeProperties withEncoding(Object encoding) {
+ this.encoding = encoding;
+ return this;
+ }
+
/**
* Get the password property: The Azure key vault secret reference of password in connection string.
*
@@ -122,6 +413,17 @@ public void validate() {
public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
jsonWriter.writeStartObject();
jsonWriter.writeUntypedField("connectionString", this.connectionString);
+ jsonWriter.writeUntypedField("server", this.server);
+ jsonWriter.writeUntypedField("port", this.port);
+ jsonWriter.writeUntypedField("username", this.username);
+ jsonWriter.writeUntypedField("database", this.database);
+ jsonWriter.writeUntypedField("sslMode", this.sslMode);
+ jsonWriter.writeUntypedField("timeout", this.timeout);
+ jsonWriter.writeUntypedField("commandTimeout", this.commandTimeout);
+ jsonWriter.writeUntypedField("trustServerCertificate", this.trustServerCertificate);
+ jsonWriter.writeUntypedField("readBufferSize", this.readBufferSize);
+ jsonWriter.writeUntypedField("timezone", this.timezone);
+ jsonWriter.writeUntypedField("encoding", this.encoding);
jsonWriter.writeJsonField("password", this.password);
jsonWriter.writeStringField("encryptedCredential", this.encryptedCredential);
return jsonWriter.writeEndObject();
@@ -145,6 +447,29 @@ public static AzurePostgreSqlLinkedServiceTypeProperties fromJson(JsonReader jso
if ("connectionString".equals(fieldName)) {
deserializedAzurePostgreSqlLinkedServiceTypeProperties.connectionString = reader.readUntyped();
+ } else if ("server".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.server = reader.readUntyped();
+ } else if ("port".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.port = reader.readUntyped();
+ } else if ("username".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.username = reader.readUntyped();
+ } else if ("database".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.database = reader.readUntyped();
+ } else if ("sslMode".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.sslMode = reader.readUntyped();
+ } else if ("timeout".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.timeout = reader.readUntyped();
+ } else if ("commandTimeout".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.commandTimeout = reader.readUntyped();
+ } else if ("trustServerCertificate".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.trustServerCertificate
+ = reader.readUntyped();
+ } else if ("readBufferSize".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.readBufferSize = reader.readUntyped();
+ } else if ("timezone".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.timezone = reader.readUntyped();
+ } else if ("encoding".equals(fieldName)) {
+ deserializedAzurePostgreSqlLinkedServiceTypeProperties.encoding = reader.readUntyped();
} else if ("password".equals(fieldName)) {
deserializedAzurePostgreSqlLinkedServiceTypeProperties.password
= AzureKeyVaultSecretReference.fromJson(reader);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDWLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDWLinkedServiceTypeProperties.java
index 433233dc0aad..664376a56f58 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDWLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDWLinkedServiceTypeProperties.java
@@ -542,7 +542,6 @@ public AzureSqlDWLinkedServiceTypeProperties withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (password() != null) {
password().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDatabaseLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDatabaseLinkedServiceTypeProperties.java
index 72fc89b3a368..1a3516e04bb2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDatabaseLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlDatabaseLinkedServiceTypeProperties.java
@@ -569,7 +569,6 @@ public AzureSqlDatabaseLinkedServiceTypeProperties withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (password() != null) {
password().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlMILinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlMILinkedServiceTypeProperties.java
index 6b4a1c2148ed..ad6b6aa08c83 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlMILinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureSqlMILinkedServiceTypeProperties.java
@@ -568,7 +568,6 @@ public AzureSqlMILinkedServiceTypeProperties withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (password() != null) {
password().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureTableStorageLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureTableStorageLinkedServiceTypeProperties.java
index 78c8768b0aff..45b8db7cc344 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureTableStorageLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/AzureTableStorageLinkedServiceTypeProperties.java
@@ -128,10 +128,15 @@ public AzureTableStorageLinkedServiceTypeProperties withEncryptedCredential(Stri
*/
@Override
public void validate() {
- super.validate();
if (credential() != null) {
credential().validate();
}
+ if (accountKey() != null) {
+ accountKey().validate();
+ }
+ if (sasToken() != null) {
+ sasToken().validate();
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ExecutePowerQueryActivityTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ExecutePowerQueryActivityTypeProperties.java
index 33475bf2c7ef..0141b1980428 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ExecutePowerQueryActivityTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ExecutePowerQueryActivityTypeProperties.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.fluent.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -172,7 +173,6 @@ public ExecutePowerQueryActivityTypeProperties withSourceStagingConcurrency(Obje
*/
@Override
public void validate() {
- super.validate();
if (sinks() != null) {
sinks().values().forEach(e -> {
if (e != null) {
@@ -183,8 +183,29 @@ public void validate() {
if (queries() != null) {
queries().forEach(e -> e.validate());
}
+ if (dataFlow() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property dataFlow in model ExecutePowerQueryActivityTypeProperties"));
+ } else {
+ dataFlow().validate();
+ }
+ if (staging() != null) {
+ staging().validate();
+ }
+ if (integrationRuntime() != null) {
+ integrationRuntime().validate();
+ }
+ if (continuationSettings() != null) {
+ continuationSettings().validate();
+ }
+ if (compute() != null) {
+ compute().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ExecutePowerQueryActivityTypeProperties.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/FactoryInner.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/FactoryInner.java
index 3357e534d23b..f24ddea1be2f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/FactoryInner.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/FactoryInner.java
@@ -46,9 +46,9 @@ public final class FactoryInner extends Resource {
private Map additionalProperties;
/*
- * Fully qualified resource Id for the resource.
+ * The type of the resource.
*/
- private String id;
+ private String type;
/*
* The name of the resource.
@@ -56,9 +56,9 @@ public final class FactoryInner extends Resource {
private String name;
/*
- * The type of the resource.
+ * Fully qualified resource Id for the resource.
*/
- private String type;
+ private String id;
/**
* Creates an instance of FactoryInner class.
@@ -125,13 +125,13 @@ public FactoryInner withAdditionalProperties(Map additionalPrope
}
/**
- * Get the id property: Fully qualified resource Id for the resource.
+ * Get the type property: The type of the resource.
*
- * @return the id value.
+ * @return the type value.
*/
@Override
- public String id() {
- return this.id;
+ public String type() {
+ return this.type;
}
/**
@@ -145,13 +145,13 @@ public String name() {
}
/**
- * Get the type property: The type of the resource.
+ * Get the id property: Fully qualified resource Id for the resource.
*
- * @return the type value.
+ * @return the id value.
*/
@Override
- public String type() {
- return this.type;
+ public String id() {
+ return this.id;
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/IcebergDatasetTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/IcebergDatasetTypeProperties.java
new file mode 100644
index 000000000000..2a52e9419c48
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/IcebergDatasetTypeProperties.java
@@ -0,0 +1,107 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.fluent.models;
+
+import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonSerializable;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import com.azure.resourcemanager.datafactory.models.DatasetLocation;
+import java.io.IOException;
+
+/**
+ * Iceberg dataset properties.
+ */
+@Fluent
+public final class IcebergDatasetTypeProperties implements JsonSerializable {
+ /*
+ * The location of the iceberg storage. Setting a file name is not allowed for iceberg format.
+ */
+ private DatasetLocation location;
+
+ /**
+ * Creates an instance of IcebergDatasetTypeProperties class.
+ */
+ public IcebergDatasetTypeProperties() {
+ }
+
+ /**
+ * Get the location property: The location of the iceberg storage. Setting a file name is not allowed for iceberg
+ * format.
+ *
+ * @return the location value.
+ */
+ public DatasetLocation location() {
+ return this.location;
+ }
+
+ /**
+ * Set the location property: The location of the iceberg storage. Setting a file name is not allowed for iceberg
+ * format.
+ *
+ * @param location the location value to set.
+ * @return the IcebergDatasetTypeProperties object itself.
+ */
+ public IcebergDatasetTypeProperties withLocation(DatasetLocation location) {
+ this.location = location;
+ return this;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ public void validate() {
+ if (location() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property location in model IcebergDatasetTypeProperties"));
+ } else {
+ location().validate();
+ }
+ }
+
+ private static final ClientLogger LOGGER = new ClientLogger(IcebergDatasetTypeProperties.class);
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeJsonField("location", this.location);
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of IcebergDatasetTypeProperties from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of IcebergDatasetTypeProperties if the JsonReader was pointing to an instance of it, or null
+ * if it was pointing to JSON null.
+ * @throws IllegalStateException If the deserialized JSON object was missing any required properties.
+ * @throws IOException If an error occurs while reading the IcebergDatasetTypeProperties.
+ */
+ public static IcebergDatasetTypeProperties fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ IcebergDatasetTypeProperties deserializedIcebergDatasetTypeProperties = new IcebergDatasetTypeProperties();
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("location".equals(fieldName)) {
+ deserializedIcebergDatasetTypeProperties.location = DatasetLocation.fromJson(reader);
+ } else {
+ reader.skipChildren();
+ }
+ }
+
+ return deserializedIcebergDatasetTypeProperties;
+ });
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MariaDBLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MariaDBLinkedServiceTypeProperties.java
index febd8c48bdd0..923af3f78834 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MariaDBLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MariaDBLinkedServiceTypeProperties.java
@@ -19,7 +19,8 @@
public final class MariaDBLinkedServiceTypeProperties implements JsonSerializable {
/*
* The version of the MariaDB driver. Type: string. V1 or empty for legacy driver, V2 for new driver. V1 can support
- * connection string and property bag, V2 can only support connection string.
+ * connection string and property bag, V2 can only support connection string. The legacy driver is scheduled for
+ * deprecation by October 2024.
*/
private Object driverVersion;
@@ -48,6 +49,19 @@ public final class MariaDBLinkedServiceTypeProperties implements JsonSerializabl
*/
private Object database;
+ /*
+ * This option specifies whether the driver uses TLS encryption and verification when connecting to MariaDB. E.g.,
+ * SSLMode=<0/1/2/3/4>. Options: DISABLED (0) / PREFERRED (1) (Default) / REQUIRED (2) / VERIFY_CA (3) /
+ * VERIFY_IDENTITY (4), REQUIRED (2) is recommended to only allow connections encrypted with SSL/TLS.
+ */
+ private Object sslMode;
+
+ /*
+ * This option specifies whether to use a CA certificate from the system trust store, or from a specified PEM file.
+ * E.g. UseSystemTrustStore=<0/1>; Options: Enabled (1) / Disabled (0) (Default)
+ */
+ private Object useSystemTrustStore;
+
/*
* The Azure key vault secret reference of password in connection string.
*/
@@ -67,7 +81,8 @@ public MariaDBLinkedServiceTypeProperties() {
/**
* Get the driverVersion property: The version of the MariaDB driver. Type: string. V1 or empty for legacy driver,
- * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string.
+ * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string. The
+ * legacy driver is scheduled for deprecation by October 2024.
*
* @return the driverVersion value.
*/
@@ -77,7 +92,8 @@ public Object driverVersion() {
/**
* Set the driverVersion property: The version of the MariaDB driver. Type: string. V1 or empty for legacy driver,
- * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string.
+ * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string. The
+ * legacy driver is scheduled for deprecation by October 2024.
*
* @param driverVersion the driverVersion value to set.
* @return the MariaDBLinkedServiceTypeProperties object itself.
@@ -189,6 +205,56 @@ public MariaDBLinkedServiceTypeProperties withDatabase(Object database) {
return this;
}
+ /**
+ * Get the sslMode property: This option specifies whether the driver uses TLS encryption and verification when
+ * connecting to MariaDB. E.g., SSLMode=<0/1/2/3/4>. Options: DISABLED (0) / PREFERRED (1) (Default) /
+ * REQUIRED (2) / VERIFY_CA (3) / VERIFY_IDENTITY (4), REQUIRED (2) is recommended to only allow connections
+ * encrypted with SSL/TLS.
+ *
+ * @return the sslMode value.
+ */
+ public Object sslMode() {
+ return this.sslMode;
+ }
+
+ /**
+ * Set the sslMode property: This option specifies whether the driver uses TLS encryption and verification when
+ * connecting to MariaDB. E.g., SSLMode=<0/1/2/3/4>. Options: DISABLED (0) / PREFERRED (1) (Default) /
+ * REQUIRED (2) / VERIFY_CA (3) / VERIFY_IDENTITY (4), REQUIRED (2) is recommended to only allow connections
+ * encrypted with SSL/TLS.
+ *
+ * @param sslMode the sslMode value to set.
+ * @return the MariaDBLinkedServiceTypeProperties object itself.
+ */
+ public MariaDBLinkedServiceTypeProperties withSslMode(Object sslMode) {
+ this.sslMode = sslMode;
+ return this;
+ }
+
+ /**
+ * Get the useSystemTrustStore property: This option specifies whether to use a CA certificate from the system trust
+ * store, or from a specified PEM file. E.g. UseSystemTrustStore=<0/1>; Options: Enabled (1) / Disabled (0)
+ * (Default).
+ *
+ * @return the useSystemTrustStore value.
+ */
+ public Object useSystemTrustStore() {
+ return this.useSystemTrustStore;
+ }
+
+ /**
+ * Set the useSystemTrustStore property: This option specifies whether to use a CA certificate from the system trust
+ * store, or from a specified PEM file. E.g. UseSystemTrustStore=<0/1>; Options: Enabled (1) / Disabled (0)
+ * (Default).
+ *
+ * @param useSystemTrustStore the useSystemTrustStore value to set.
+ * @return the MariaDBLinkedServiceTypeProperties object itself.
+ */
+ public MariaDBLinkedServiceTypeProperties withUseSystemTrustStore(Object useSystemTrustStore) {
+ this.useSystemTrustStore = useSystemTrustStore;
+ return this;
+ }
+
/**
* Get the password property: The Azure key vault secret reference of password in connection string.
*
@@ -254,6 +320,8 @@ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
jsonWriter.writeUntypedField("port", this.port);
jsonWriter.writeUntypedField("username", this.username);
jsonWriter.writeUntypedField("database", this.database);
+ jsonWriter.writeUntypedField("sslMode", this.sslMode);
+ jsonWriter.writeUntypedField("useSystemTrustStore", this.useSystemTrustStore);
jsonWriter.writeJsonField("password", this.password);
jsonWriter.writeStringField("encryptedCredential", this.encryptedCredential);
return jsonWriter.writeEndObject();
@@ -287,6 +355,10 @@ public static MariaDBLinkedServiceTypeProperties fromJson(JsonReader jsonReader)
deserializedMariaDBLinkedServiceTypeProperties.username = reader.readUntyped();
} else if ("database".equals(fieldName)) {
deserializedMariaDBLinkedServiceTypeProperties.database = reader.readUntyped();
+ } else if ("sslMode".equals(fieldName)) {
+ deserializedMariaDBLinkedServiceTypeProperties.sslMode = reader.readUntyped();
+ } else if ("useSystemTrustStore".equals(fieldName)) {
+ deserializedMariaDBLinkedServiceTypeProperties.useSystemTrustStore = reader.readUntyped();
} else if ("password".equals(fieldName)) {
deserializedMariaDBLinkedServiceTypeProperties.password
= AzureKeyVaultSecretReference.fromJson(reader);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MySqlLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MySqlLinkedServiceTypeProperties.java
index c623d9ccaf2c..61bc20c6709d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MySqlLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/MySqlLinkedServiceTypeProperties.java
@@ -69,6 +69,44 @@ public final class MySqlLinkedServiceTypeProperties implements JsonSerializable<
*/
private String encryptedCredential;
+ /*
+ * This allows the special “zero” date value 0000-00-00 to be retrieved from the database. Type: boolean.
+ */
+ private Object allowZeroDateTime;
+
+ /*
+ * The length of time (in seconds) to wait for a connection to the server before terminating the attempt and
+ * generating an error. Type: integer.
+ */
+ private Object connectionTimeout;
+
+ /*
+ * True to return DateTime.MinValue for date or datetime columns that have disallowed values. Type: boolean.
+ */
+ private Object convertZeroDateTime;
+
+ /*
+ * Determines which column type (if any) should be read as a GUID. Type: string. None: No column types are
+ * automatically read as a Guid; Char36: All CHAR(36) columns are read/written as a Guid using lowercase hex with
+ * hyphens, which matches UUID.
+ */
+ private Object guidFormat;
+
+ /*
+ * The path to the client’s SSL certificate file in PEM format. SslKey must also be specified. Type: string.
+ */
+ private Object sslCert;
+
+ /*
+ * The path to the client’s SSL private key in PEM format. SslCert must also be specified. Type: string.
+ */
+ private Object sslKey;
+
+ /*
+ * When set to true, TINYINT(1) values are returned as booleans. Type: bool.
+ */
+ private Object treatTinyAsBoolean;
+
/**
* Creates an instance of MySqlLinkedServiceTypeProperties class.
*/
@@ -285,6 +323,160 @@ public MySqlLinkedServiceTypeProperties withEncryptedCredential(String encrypted
return this;
}
+ /**
+ * Get the allowZeroDateTime property: This allows the special “zero” date value 0000-00-00 to be retrieved from the
+ * database. Type: boolean.
+ *
+ * @return the allowZeroDateTime value.
+ */
+ public Object allowZeroDateTime() {
+ return this.allowZeroDateTime;
+ }
+
+ /**
+ * Set the allowZeroDateTime property: This allows the special “zero” date value 0000-00-00 to be retrieved from the
+ * database. Type: boolean.
+ *
+ * @param allowZeroDateTime the allowZeroDateTime value to set.
+ * @return the MySqlLinkedServiceTypeProperties object itself.
+ */
+ public MySqlLinkedServiceTypeProperties withAllowZeroDateTime(Object allowZeroDateTime) {
+ this.allowZeroDateTime = allowZeroDateTime;
+ return this;
+ }
+
+ /**
+ * Get the connectionTimeout property: The length of time (in seconds) to wait for a connection to the server before
+ * terminating the attempt and generating an error. Type: integer.
+ *
+ * @return the connectionTimeout value.
+ */
+ public Object connectionTimeout() {
+ return this.connectionTimeout;
+ }
+
+ /**
+ * Set the connectionTimeout property: The length of time (in seconds) to wait for a connection to the server before
+ * terminating the attempt and generating an error. Type: integer.
+ *
+ * @param connectionTimeout the connectionTimeout value to set.
+ * @return the MySqlLinkedServiceTypeProperties object itself.
+ */
+ public MySqlLinkedServiceTypeProperties withConnectionTimeout(Object connectionTimeout) {
+ this.connectionTimeout = connectionTimeout;
+ return this;
+ }
+
+ /**
+ * Get the convertZeroDateTime property: True to return DateTime.MinValue for date or datetime columns that have
+ * disallowed values. Type: boolean.
+ *
+ * @return the convertZeroDateTime value.
+ */
+ public Object convertZeroDateTime() {
+ return this.convertZeroDateTime;
+ }
+
+ /**
+ * Set the convertZeroDateTime property: True to return DateTime.MinValue for date or datetime columns that have
+ * disallowed values. Type: boolean.
+ *
+ * @param convertZeroDateTime the convertZeroDateTime value to set.
+ * @return the MySqlLinkedServiceTypeProperties object itself.
+ */
+ public MySqlLinkedServiceTypeProperties withConvertZeroDateTime(Object convertZeroDateTime) {
+ this.convertZeroDateTime = convertZeroDateTime;
+ return this;
+ }
+
+ /**
+ * Get the guidFormat property: Determines which column type (if any) should be read as a GUID. Type: string. None:
+ * No column types are automatically read as a Guid; Char36: All CHAR(36) columns are read/written as a Guid using
+ * lowercase hex with hyphens, which matches UUID.
+ *
+ * @return the guidFormat value.
+ */
+ public Object guidFormat() {
+ return this.guidFormat;
+ }
+
+ /**
+ * Set the guidFormat property: Determines which column type (if any) should be read as a GUID. Type: string. None:
+ * No column types are automatically read as a Guid; Char36: All CHAR(36) columns are read/written as a Guid using
+ * lowercase hex with hyphens, which matches UUID.
+ *
+ * @param guidFormat the guidFormat value to set.
+ * @return the MySqlLinkedServiceTypeProperties object itself.
+ */
+ public MySqlLinkedServiceTypeProperties withGuidFormat(Object guidFormat) {
+ this.guidFormat = guidFormat;
+ return this;
+ }
+
+ /**
+ * Get the sslCert property: The path to the client’s SSL certificate file in PEM format. SslKey must also be
+ * specified. Type: string.
+ *
+ * @return the sslCert value.
+ */
+ public Object sslCert() {
+ return this.sslCert;
+ }
+
+ /**
+ * Set the sslCert property: The path to the client’s SSL certificate file in PEM format. SslKey must also be
+ * specified. Type: string.
+ *
+ * @param sslCert the sslCert value to set.
+ * @return the MySqlLinkedServiceTypeProperties object itself.
+ */
+ public MySqlLinkedServiceTypeProperties withSslCert(Object sslCert) {
+ this.sslCert = sslCert;
+ return this;
+ }
+
+ /**
+ * Get the sslKey property: The path to the client’s SSL private key in PEM format. SslCert must also be specified.
+ * Type: string.
+ *
+ * @return the sslKey value.
+ */
+ public Object sslKey() {
+ return this.sslKey;
+ }
+
+ /**
+ * Set the sslKey property: The path to the client’s SSL private key in PEM format. SslCert must also be specified.
+ * Type: string.
+ *
+ * @param sslKey the sslKey value to set.
+ * @return the MySqlLinkedServiceTypeProperties object itself.
+ */
+ public MySqlLinkedServiceTypeProperties withSslKey(Object sslKey) {
+ this.sslKey = sslKey;
+ return this;
+ }
+
+ /**
+ * Get the treatTinyAsBoolean property: When set to true, TINYINT(1) values are returned as booleans. Type: bool.
+ *
+ * @return the treatTinyAsBoolean value.
+ */
+ public Object treatTinyAsBoolean() {
+ return this.treatTinyAsBoolean;
+ }
+
+ /**
+ * Set the treatTinyAsBoolean property: When set to true, TINYINT(1) values are returned as booleans. Type: bool.
+ *
+ * @param treatTinyAsBoolean the treatTinyAsBoolean value to set.
+ * @return the MySqlLinkedServiceTypeProperties object itself.
+ */
+ public MySqlLinkedServiceTypeProperties withTreatTinyAsBoolean(Object treatTinyAsBoolean) {
+ this.treatTinyAsBoolean = treatTinyAsBoolean;
+ return this;
+ }
+
/**
* Validates the instance.
*
@@ -312,6 +504,13 @@ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
jsonWriter.writeUntypedField("useSystemTrustStore", this.useSystemTrustStore);
jsonWriter.writeJsonField("password", this.password);
jsonWriter.writeStringField("encryptedCredential", this.encryptedCredential);
+ jsonWriter.writeUntypedField("allowZeroDateTime", this.allowZeroDateTime);
+ jsonWriter.writeUntypedField("connectionTimeout", this.connectionTimeout);
+ jsonWriter.writeUntypedField("convertZeroDateTime", this.convertZeroDateTime);
+ jsonWriter.writeUntypedField("guidFormat", this.guidFormat);
+ jsonWriter.writeUntypedField("sslCert", this.sslCert);
+ jsonWriter.writeUntypedField("sslKey", this.sslKey);
+ jsonWriter.writeUntypedField("treatTinyAsBoolean", this.treatTinyAsBoolean);
return jsonWriter.writeEndObject();
}
@@ -352,6 +551,20 @@ public static MySqlLinkedServiceTypeProperties fromJson(JsonReader jsonReader) t
= AzureKeyVaultSecretReference.fromJson(reader);
} else if ("encryptedCredential".equals(fieldName)) {
deserializedMySqlLinkedServiceTypeProperties.encryptedCredential = reader.getString();
+ } else if ("allowZeroDateTime".equals(fieldName)) {
+ deserializedMySqlLinkedServiceTypeProperties.allowZeroDateTime = reader.readUntyped();
+ } else if ("connectionTimeout".equals(fieldName)) {
+ deserializedMySqlLinkedServiceTypeProperties.connectionTimeout = reader.readUntyped();
+ } else if ("convertZeroDateTime".equals(fieldName)) {
+ deserializedMySqlLinkedServiceTypeProperties.convertZeroDateTime = reader.readUntyped();
+ } else if ("guidFormat".equals(fieldName)) {
+ deserializedMySqlLinkedServiceTypeProperties.guidFormat = reader.readUntyped();
+ } else if ("sslCert".equals(fieldName)) {
+ deserializedMySqlLinkedServiceTypeProperties.sslCert = reader.readUntyped();
+ } else if ("sslKey".equals(fieldName)) {
+ deserializedMySqlLinkedServiceTypeProperties.sslKey = reader.readUntyped();
+ } else if ("treatTinyAsBoolean".equals(fieldName)) {
+ deserializedMySqlLinkedServiceTypeProperties.treatTinyAsBoolean = reader.readUntyped();
} else {
reader.skipChildren();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/PostgreSqlV2LinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/PostgreSqlV2LinkedServiceTypeProperties.java
index 81bcfed63827..b925a32b49cc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/PostgreSqlV2LinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/PostgreSqlV2LinkedServiceTypeProperties.java
@@ -39,6 +39,11 @@ public final class PostgreSqlV2LinkedServiceTypeProperties
*/
private Object database;
+ /*
+ * The authentication type to use. Type: string.
+ */
+ private Object authenticationType;
+
/*
* SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4: verify-ca, 5: verify-full.
* Type: integer.
@@ -205,6 +210,26 @@ public PostgreSqlV2LinkedServiceTypeProperties withDatabase(Object database) {
return this;
}
+ /**
+ * Get the authenticationType property: The authentication type to use. Type: string.
+ *
+ * @return the authenticationType value.
+ */
+ public Object authenticationType() {
+ return this.authenticationType;
+ }
+
+ /**
+ * Set the authenticationType property: The authentication type to use. Type: string.
+ *
+ * @param authenticationType the authenticationType value to set.
+ * @return the PostgreSqlV2LinkedServiceTypeProperties object itself.
+ */
+ public PostgreSqlV2LinkedServiceTypeProperties withAuthenticationType(Object authenticationType) {
+ this.authenticationType = authenticationType;
+ return this;
+ }
+
/**
* Get the sslMode property: SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4:
* verify-ca, 5: verify-full. Type: integer.
@@ -544,6 +569,11 @@ public void validate() {
.log(new IllegalArgumentException(
"Missing required property database in model PostgreSqlV2LinkedServiceTypeProperties"));
}
+ if (authenticationType() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property authenticationType in model PostgreSqlV2LinkedServiceTypeProperties"));
+ }
if (sslMode() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -565,6 +595,7 @@ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
jsonWriter.writeUntypedField("server", this.server);
jsonWriter.writeUntypedField("username", this.username);
jsonWriter.writeUntypedField("database", this.database);
+ jsonWriter.writeUntypedField("authenticationType", this.authenticationType);
jsonWriter.writeUntypedField("sslMode", this.sslMode);
jsonWriter.writeUntypedField("port", this.port);
jsonWriter.writeUntypedField("schema", this.schema);
@@ -607,6 +638,8 @@ public static PostgreSqlV2LinkedServiceTypeProperties fromJson(JsonReader jsonRe
deserializedPostgreSqlV2LinkedServiceTypeProperties.username = reader.readUntyped();
} else if ("database".equals(fieldName)) {
deserializedPostgreSqlV2LinkedServiceTypeProperties.database = reader.readUntyped();
+ } else if ("authenticationType".equals(fieldName)) {
+ deserializedPostgreSqlV2LinkedServiceTypeProperties.authenticationType = reader.readUntyped();
} else if ("sslMode".equals(fieldName)) {
deserializedPostgreSqlV2LinkedServiceTypeProperties.sslMode = reader.readUntyped();
} else if ("port".equals(fieldName)) {
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ScriptActivityTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ScriptActivityTypeProperties.java
index ae1b4c8dcd73..4c7addb4e61c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ScriptActivityTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/ScriptActivityTypeProperties.java
@@ -35,6 +35,12 @@ public final class ScriptActivityTypeProperties implements JsonSerializable writer.writeJson(element));
jsonWriter.writeJsonField("logSettings", this.logSettings);
+ jsonWriter.writeUntypedField("returnMultistatementResult", this.returnMultistatementResult);
return jsonWriter.writeEndObject();
}
@@ -153,6 +184,8 @@ public static ScriptActivityTypeProperties fromJson(JsonReader jsonReader) throw
} else if ("logSettings".equals(fieldName)) {
deserializedScriptActivityTypeProperties.logSettings
= ScriptActivityTypePropertiesLogSettings.fromJson(reader);
+ } else if ("returnMultistatementResult".equals(fieldName)) {
+ deserializedScriptActivityTypeProperties.returnMultistatementResult = reader.readUntyped();
} else {
reader.skipChildren();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SnowflakeLinkedV2ServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SnowflakeLinkedV2ServiceTypeProperties.java
index 4705f7807303..fedce0d3a006 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SnowflakeLinkedV2ServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SnowflakeLinkedV2ServiceTypeProperties.java
@@ -80,6 +80,11 @@ public final class SnowflakeLinkedV2ServiceTypeProperties
*/
private SecretBase privateKeyPassphrase;
+ /*
+ * The host name of the Snowflake account.
+ */
+ private Object host;
+
/*
* The encrypted credential used for authentication. Credentials are encrypted using the integration runtime
* credential manager. Type: string.
@@ -345,6 +350,26 @@ public SnowflakeLinkedV2ServiceTypeProperties withPrivateKeyPassphrase(SecretBas
return this;
}
+ /**
+ * Get the host property: The host name of the Snowflake account.
+ *
+ * @return the host value.
+ */
+ public Object host() {
+ return this.host;
+ }
+
+ /**
+ * Set the host property: The host name of the Snowflake account.
+ *
+ * @param host the host value to set.
+ * @return the SnowflakeLinkedV2ServiceTypeProperties object itself.
+ */
+ public SnowflakeLinkedV2ServiceTypeProperties withHost(Object host) {
+ this.host = host;
+ return this;
+ }
+
/**
* Get the encryptedCredential property: The encrypted credential used for authentication. Credentials are encrypted
* using the integration runtime credential manager. Type: string.
@@ -423,6 +448,7 @@ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
jsonWriter.writeUntypedField("scope", this.scope);
jsonWriter.writeJsonField("privateKey", this.privateKey);
jsonWriter.writeJsonField("privateKeyPassphrase", this.privateKeyPassphrase);
+ jsonWriter.writeUntypedField("host", this.host);
jsonWriter.writeStringField("encryptedCredential", this.encryptedCredential);
return jsonWriter.writeEndObject();
}
@@ -470,6 +496,8 @@ public static SnowflakeLinkedV2ServiceTypeProperties fromJson(JsonReader jsonRea
} else if ("privateKeyPassphrase".equals(fieldName)) {
deserializedSnowflakeLinkedV2ServiceTypeProperties.privateKeyPassphrase
= SecretBase.fromJson(reader);
+ } else if ("host".equals(fieldName)) {
+ deserializedSnowflakeLinkedV2ServiceTypeProperties.host = reader.readUntyped();
} else if ("encryptedCredential".equals(fieldName)) {
deserializedSnowflakeLinkedV2ServiceTypeProperties.encryptedCredential = reader.getString();
} else {
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SqlServerLinkedServiceTypeProperties.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SqlServerLinkedServiceTypeProperties.java
index 990d5cd8a59e..0e098a9f5d33 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SqlServerLinkedServiceTypeProperties.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/fluent/models/SqlServerLinkedServiceTypeProperties.java
@@ -387,7 +387,6 @@ public SqlServerLinkedServiceTypeProperties withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (password() != null) {
password().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/DataFactoryManagementClientImpl.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/DataFactoryManagementClientImpl.java
index f7aa8ce11541..a8b083a34e5f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/DataFactoryManagementClientImpl.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/DataFactoryManagementClientImpl.java
@@ -13,8 +13,8 @@
import com.azure.core.management.AzureEnvironment;
import com.azure.core.management.exception.ManagementError;
import com.azure.core.management.exception.ManagementException;
-import com.azure.core.management.polling.PollerFactory;
import com.azure.core.management.polling.PollResult;
+import com.azure.core.management.polling.PollerFactory;
import com.azure.core.util.Context;
import com.azure.core.util.CoreUtils;
import com.azure.core.util.logging.ClientLogger;
@@ -42,8 +42,8 @@
import com.azure.resourcemanager.datafactory.fluent.OperationsClient;
import com.azure.resourcemanager.datafactory.fluent.PipelineRunsClient;
import com.azure.resourcemanager.datafactory.fluent.PipelinesClient;
-import com.azure.resourcemanager.datafactory.fluent.PrivateEndpointConnectionOperationsClient;
import com.azure.resourcemanager.datafactory.fluent.PrivateEndPointConnectionsClient;
+import com.azure.resourcemanager.datafactory.fluent.PrivateEndpointConnectionOperationsClient;
import com.azure.resourcemanager.datafactory.fluent.PrivateLinkResourcesClient;
import com.azure.resourcemanager.datafactory.fluent.TriggerRunsClient;
import com.azure.resourcemanager.datafactory.fluent.TriggersClient;
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/IntegrationRuntimesImpl.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/IntegrationRuntimesImpl.java
index 99f1479a8f33..f66adc152159 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/IntegrationRuntimesImpl.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/IntegrationRuntimesImpl.java
@@ -23,8 +23,8 @@
import com.azure.resourcemanager.datafactory.models.IntegrationRuntimeOutboundNetworkDependenciesEndpointsResponse;
import com.azure.resourcemanager.datafactory.models.IntegrationRuntimeRegenerateKeyParameters;
import com.azure.resourcemanager.datafactory.models.IntegrationRuntimeResource;
-import com.azure.resourcemanager.datafactory.models.IntegrationRuntimes;
import com.azure.resourcemanager.datafactory.models.IntegrationRuntimeStatusResponse;
+import com.azure.resourcemanager.datafactory.models.IntegrationRuntimes;
import com.azure.resourcemanager.datafactory.models.LinkedIntegrationRuntimeRequest;
public final class IntegrationRuntimesImpl implements IntegrationRuntimes {
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/PrivateEndPointConnectionsImpl.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/PrivateEndPointConnectionsImpl.java
index fba65ca5e909..021d88dc94d2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/PrivateEndPointConnectionsImpl.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/PrivateEndPointConnectionsImpl.java
@@ -9,8 +9,8 @@
import com.azure.core.util.logging.ClientLogger;
import com.azure.resourcemanager.datafactory.fluent.PrivateEndPointConnectionsClient;
import com.azure.resourcemanager.datafactory.fluent.models.PrivateEndpointConnectionResourceInner;
-import com.azure.resourcemanager.datafactory.models.PrivateEndpointConnectionResource;
import com.azure.resourcemanager.datafactory.models.PrivateEndPointConnections;
+import com.azure.resourcemanager.datafactory.models.PrivateEndpointConnectionResource;
public final class PrivateEndPointConnectionsImpl implements PrivateEndPointConnections {
private static final ClientLogger LOGGER = new ClientLogger(PrivateEndPointConnectionsImpl.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/TriggersImpl.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/TriggersImpl.java
index 538e0e23926c..5e10c47079c8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/TriggersImpl.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/implementation/TriggersImpl.java
@@ -16,8 +16,8 @@
import com.azure.resourcemanager.datafactory.models.TriggerFilterParameters;
import com.azure.resourcemanager.datafactory.models.TriggerQueryResponse;
import com.azure.resourcemanager.datafactory.models.TriggerResource;
-import com.azure.resourcemanager.datafactory.models.Triggers;
import com.azure.resourcemanager.datafactory.models.TriggerSubscriptionOperationStatus;
+import com.azure.resourcemanager.datafactory.models.Triggers;
public final class TriggersImpl implements Triggers {
private static final ClientLogger LOGGER = new ClientLogger(TriggersImpl.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsLinkedService.java
index ff68f2f97f77..512620279e78 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsLinkedService.java
@@ -347,7 +347,6 @@ public AmazonMwsLinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -355,6 +354,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AmazonMwsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsObjectDataset.java
index 09b73f360d13..99c2a0397509 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public AmazonMwsObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AmazonMwsObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AmazonMwsObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsSource.java
index 1b88c960675a..d38ffea70bf7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonMwsSource.java
@@ -126,7 +126,6 @@ public AmazonMwsSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleLinkedService.java
index fb7a44d33c99..5159525138e6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleLinkedService.java
@@ -180,7 +180,6 @@ public AmazonRdsForOracleLinkedService withEncryptedCredential(String encryptedC
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AmazonRdsForOracleLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleSource.java
index 87214d2233f3..db3e4cebfd87 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleSource.java
@@ -219,7 +219,6 @@ public AmazonRdsForOracleSource withDisableMetricsCollection(Object disableMetri
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleTableDataset.java
index 3f9fe8b53d08..c3fd1789a903 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForOracleTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -174,12 +175,30 @@ public AmazonRdsForOracleTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AmazonRdsForOracleTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AmazonRdsForOracleTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerLinkedService.java
index 64ae768092a7..17c08c744cbb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerLinkedService.java
@@ -753,7 +753,6 @@ public AmazonRdsForSqlServerLinkedService withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -761,6 +760,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AmazonRdsForSqlServerLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerSource.java
index 6e30434c5c7d..561ee63341ac 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerSource.java
@@ -288,7 +288,6 @@ public AmazonRdsForSqlServerSource withDisableMetricsCollection(Object disableMe
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerTableDataset.java
index 1f77c4e45bbb..da262679c069 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRdsForSqlServerTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -174,12 +175,30 @@ public AmazonRdsForSqlServerTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AmazonRdsForSqlServerTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AmazonRdsForSqlServerTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftLinkedService.java
index 6b6e5feeba8e..664321c20a0c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftLinkedService.java
@@ -256,7 +256,6 @@ public AmazonRedshiftLinkedService withEncryptedCredential(String encryptedCrede
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -264,6 +263,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AmazonRedshiftLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftSource.java
index 23df97e0dc0e..08d34d374641 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftSource.java
@@ -155,7 +155,6 @@ public AmazonRedshiftSource withDisableMetricsCollection(Object disableMetricsCo
*/
@Override
public void validate() {
- super.validate();
if (redshiftUnloadSettings() != null) {
redshiftUnloadSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftTableDataset.java
index 21486152a68b..155e7ebc39ec 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonRedshiftTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public AmazonRedshiftTableDataset withSchemaTypePropertiesSchema(Object schema)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AmazonRedshiftTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AmazonRedshiftTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLinkedService.java
index 411803d26e60..2ee59166e1c2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLinkedService.java
@@ -235,7 +235,6 @@ public AmazonS3CompatibleLinkedService withEncryptedCredential(String encryptedC
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -243,6 +242,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AmazonS3CompatibleLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLocation.java
index 85879937f3eb..1f54d89337ae 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleLocation.java
@@ -117,7 +117,6 @@ public AmazonS3CompatibleLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleReadSettings.java
index 9d1cbbaf6be7..313c59cb474c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3CompatibleReadSettings.java
@@ -336,7 +336,6 @@ public AmazonS3CompatibleReadSettings withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Dataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Dataset.java
index dc2829d3cad8..0ebae08a48ab 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Dataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Dataset.java
@@ -317,7 +317,6 @@ public AmazonS3Dataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -325,6 +324,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AmazonS3Dataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AmazonS3Dataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3LinkedService.java
index e8ea53280573..9207009e9e01 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3LinkedService.java
@@ -257,7 +257,6 @@ public AmazonS3LinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -265,6 +264,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AmazonS3LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Location.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Location.java
index b49923bbb878..e2c01e403b59 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Location.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3Location.java
@@ -115,7 +115,6 @@ public AmazonS3Location withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3ReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3ReadSettings.java
index 24f4f0dd93b2..e54b858e7d0d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3ReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AmazonS3ReadSettings.java
@@ -336,7 +336,6 @@ public AmazonS3ReadSettings withDisableMetricsCollection(Object disableMetricsCo
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppFiguresLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppFiguresLinkedService.java
index 0682491eb59a..ac3b0fd777a5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppFiguresLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppFiguresLinkedService.java
@@ -178,7 +178,6 @@ public AppFiguresLinkedService withClientKey(SecretBase clientKey) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -186,6 +185,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AppFiguresLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppendVariableActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppendVariableActivity.java
index c0d10f6a558d..3cdbb8092dcc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppendVariableActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AppendVariableActivity.java
@@ -164,7 +164,6 @@ public AppendVariableActivity withValue(Object value) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -172,6 +171,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model AppendVariableActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AppendVariableActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AsanaLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AsanaLinkedService.java
index 2724e680a1ef..3fda079f7f73 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AsanaLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AsanaLinkedService.java
@@ -155,7 +155,6 @@ public AsanaLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -163,6 +162,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AsanaLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroDataset.java
index 3b5c377401a5..0bc77de2553c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,29 @@ public AvroDataset withAvroCompressionLevel(Integer avroCompressionLevel) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property linkedServiceName in model AvroDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AvroDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroFormat.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroFormat.java
index 7dae87b63031..6e0fa6a93942 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroFormat.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroFormat.java
@@ -63,7 +63,6 @@ public AvroFormat withDeserializer(Object deserializer) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSink.java
index 2811c35188a5..6b5e00799e79 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSink.java
@@ -149,7 +149,6 @@ public AvroSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSource.java
index 797779349591..828251184dfa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroSource.java
@@ -134,7 +134,6 @@ public AvroSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroWriteSettings.java
index e5d13d6b93ee..7c27e01b0c6e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AvroWriteSettings.java
@@ -153,7 +153,6 @@ public AvroWriteSettings withFileNamePrefix(Object fileNamePrefix) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzPowerShellSetup.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzPowerShellSetup.java
index c1a608f8aa74..b6182b1f785d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzPowerShellSetup.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzPowerShellSetup.java
@@ -82,7 +82,6 @@ public AzPowerShellSetup withVersion(String version) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBatchLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBatchLinkedService.java
index 08cd8f886622..c5e858da23aa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBatchLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBatchLinkedService.java
@@ -270,7 +270,6 @@ public AzureBatchLinkedService withCredential(CredentialReference credential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -278,6 +277,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureBatchLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobDataset.java
index 4a81357629ce..ffc4787586b9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -291,12 +292,30 @@ public AzureBlobDataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureBlobDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureBlobDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSDataset.java
index 0cc2e2f2bbfd..89e0a7234b61 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -220,12 +221,30 @@ public AzureBlobFSDataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureBlobFSDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureBlobFSDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLinkedService.java
index 44b2f58c45af..3f05388c1b40 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLinkedService.java
@@ -411,7 +411,6 @@ public AzureBlobFSLinkedService withSasToken(SecretBase sasToken) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -419,6 +418,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureBlobFSLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLocation.java
index 9b444f842b3f..6cac1de79d00 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSLocation.java
@@ -90,7 +90,6 @@ public AzureBlobFSLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSReadSettings.java
index c4673ffa065c..ae2879293542 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSReadSettings.java
@@ -309,7 +309,6 @@ public AzureBlobFSReadSettings withDisableMetricsCollection(Object disableMetric
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSink.java
index 91aed7fee1b3..18b13377c8d4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSink.java
@@ -155,7 +155,6 @@ public AzureBlobFSSink withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
if (metadata() != null) {
metadata().forEach(e -> e.validate());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSource.java
index 299d0a649acd..76e5e971bd9e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSSource.java
@@ -161,7 +161,6 @@ public AzureBlobFSSource withDisableMetricsCollection(Object disableMetricsColle
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSWriteSettings.java
index db03a50b421d..5e16f8fe5525 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobFSWriteSettings.java
@@ -109,7 +109,9 @@ public AzureBlobFSWriteSettings withMetadata(List metadata) {
*/
@Override
public void validate() {
- super.validate();
+ if (metadata() != null) {
+ metadata().forEach(e -> e.validate());
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLinkedService.java
index f9fdca757d67..d4c861b8d6be 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLinkedService.java
@@ -454,7 +454,6 @@ public AzureBlobStorageLinkedService withContainerUri(Object containerUri) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -462,6 +461,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureBlobStorageLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLocation.java
index f34879047cfa..96876a9a04f3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageLocation.java
@@ -90,7 +90,6 @@ public AzureBlobStorageLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageReadSettings.java
index 1b0bac54a705..350df778c7bc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageReadSettings.java
@@ -336,7 +336,6 @@ public AzureBlobStorageReadSettings withDisableMetricsCollection(Object disableM
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageWriteSettings.java
index 0b8f73036dcf..ff3afd542e63 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureBlobStorageWriteSettings.java
@@ -109,7 +109,9 @@ public AzureBlobStorageWriteSettings withMetadata(List metadata) {
*/
@Override
public void validate() {
- super.validate();
+ if (metadata() != null) {
+ metadata().forEach(e -> e.validate());
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerCommandActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerCommandActivity.java
index 65c1e5f4799c..3c3cdc81913e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerCommandActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerCommandActivity.java
@@ -185,7 +185,6 @@ public AzureDataExplorerCommandActivity withCommandTimeout(Object commandTimeout
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -193,6 +192,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model AzureDataExplorerCommandActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureDataExplorerCommandActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerLinkedService.java
index f16b7e22195c..b43bc692ca40 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerLinkedService.java
@@ -254,7 +254,6 @@ public AzureDataExplorerLinkedService withCredential(CredentialReference credent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -262,6 +261,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureDataExplorerLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSink.java
index 0b1cdcf3a01e..1e8d54809ba9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSink.java
@@ -180,7 +180,6 @@ public AzureDataExplorerSink withDisableMetricsCollection(Object disableMetricsC
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSource.java
index 47269e42e4e8..a2e8dc25c90f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerSource.java
@@ -194,7 +194,6 @@ public AzureDataExplorerSource withDisableMetricsCollection(Object disableMetric
*/
@Override
public void validate() {
- super.validate();
if (query() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException("Missing required property query in model AzureDataExplorerSource"));
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerTableDataset.java
index 38e867ff243f..3f0b6913d812 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataExplorerTableDataset.java
@@ -150,7 +150,6 @@ public AzureDataExplorerTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -158,6 +157,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureDataExplorerTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureDataExplorerTableDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeAnalyticsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeAnalyticsLinkedService.java
index 9c18cfffbeb5..c2f297c9efe9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeAnalyticsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeAnalyticsLinkedService.java
@@ -308,7 +308,6 @@ public AzureDataLakeAnalyticsLinkedService withEncryptedCredential(String encryp
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -316,6 +315,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureDataLakeAnalyticsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreDataset.java
index 51252a28d078..e43c42bc62b5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -220,12 +221,30 @@ public AzureDataLakeStoreDataset withCompression(DatasetCompression compression)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureDataLakeStoreDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureDataLakeStoreDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLinkedService.java
index 6cc99147827f..e591059b6960 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLinkedService.java
@@ -356,7 +356,6 @@ public AzureDataLakeStoreLinkedService withCredential(CredentialReference creden
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -364,6 +363,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureDataLakeStoreLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLocation.java
index 19666aec20c8..3f1465636909 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreLocation.java
@@ -63,7 +63,6 @@ public AzureDataLakeStoreLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreReadSettings.java
index 3948f9203502..bb2952de7736 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreReadSettings.java
@@ -369,7 +369,6 @@ public AzureDataLakeStoreReadSettings withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSink.java
index 5dd39463572a..2287fff59c71 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSink.java
@@ -151,7 +151,6 @@ public AzureDataLakeStoreSink withDisableMetricsCollection(Object disableMetrics
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSource.java
index 439a567f0b37..619dca745a2e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreSource.java
@@ -109,7 +109,6 @@ public AzureDataLakeStoreSource withDisableMetricsCollection(Object disableMetri
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreWriteSettings.java
index c0788778cae8..2330a488ad97 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDataLakeStoreWriteSettings.java
@@ -112,7 +112,9 @@ public AzureDataLakeStoreWriteSettings withMetadata(List metadata)
*/
@Override
public void validate() {
- super.validate();
+ if (metadata() != null) {
+ metadata().forEach(e -> e.validate());
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeDataset.java
index ec5b45e09a50..428216d7a8ff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -170,12 +171,30 @@ public AzureDatabricksDeltaLakeDataset withDatabase(Object database) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureDatabricksDeltaLakeDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureDatabricksDeltaLakeDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeExportCommand.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeExportCommand.java
index 2b4a0d517774..edf1b11259f0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeExportCommand.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeExportCommand.java
@@ -101,7 +101,6 @@ public AzureDatabricksDeltaLakeExportCommand withTimestampFormat(Object timestam
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeImportCommand.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeImportCommand.java
index 8ad6957b6b32..32e59dfc5df3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeImportCommand.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeImportCommand.java
@@ -101,7 +101,6 @@ public AzureDatabricksDeltaLakeImportCommand withTimestampFormat(Object timestam
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeLinkedService.java
index 0595517c9229..9193468475c0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeLinkedService.java
@@ -258,7 +258,6 @@ public AzureDatabricksDeltaLakeLinkedService withWorkspaceResourceId(Object work
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -266,6 +265,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureDatabricksDeltaLakeLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSink.java
index 9fc1e73abb03..8c0e6d6ceb84 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSink.java
@@ -149,7 +149,6 @@ public AzureDatabricksDeltaLakeSink withDisableMetricsCollection(Object disableM
*/
@Override
public void validate() {
- super.validate();
if (importSettings() != null) {
importSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSource.java
index ce05fb71c6d7..2253ae058442 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksDeltaLakeSource.java
@@ -133,7 +133,6 @@ public AzureDatabricksDeltaLakeSource withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
if (exportSettings() != null) {
exportSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksLinkedService.java
index ee0c0227291c..48a52f60eaaf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureDatabricksLinkedService.java
@@ -593,7 +593,6 @@ public AzureDatabricksLinkedService withCredential(CredentialReference credentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -601,6 +600,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureDatabricksLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLinkedService.java
index c4b52acaea6f..2d7665831b08 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLinkedService.java
@@ -396,7 +396,6 @@ public AzureFileStorageLinkedService withCredential(CredentialReference credenti
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -404,6 +403,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureFileStorageLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLocation.java
index ed0bc0346ec1..1646d189d875 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageLocation.java
@@ -63,7 +63,6 @@ public AzureFileStorageLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageReadSettings.java
index 88d9eb22d025..1ae956621d31 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageReadSettings.java
@@ -337,7 +337,6 @@ public AzureFileStorageReadSettings withDisableMetricsCollection(Object disableM
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageWriteSettings.java
index 90db66462213..8cc7de1145bf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFileStorageWriteSettings.java
@@ -82,7 +82,9 @@ public AzureFileStorageWriteSettings withMetadata(List metadata) {
*/
@Override
public void validate() {
- super.validate();
+ if (metadata() != null) {
+ metadata().forEach(e -> e.validate());
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionActivity.java
index 764fac37fb24..e4dfcf36263a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionActivity.java
@@ -234,7 +234,6 @@ public AzureFunctionActivity withBody(Object body) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -242,6 +241,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model AzureFunctionActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureFunctionActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionLinkedService.java
index 2c4cd612a09b..0fa3d9d57691 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureFunctionLinkedService.java
@@ -254,7 +254,6 @@ public AzureFunctionLinkedService withAuthentication(Object authentication) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -262,6 +261,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureFunctionLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultLinkedService.java
index bf8c259828ce..a98624549ef7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultLinkedService.java
@@ -156,7 +156,6 @@ public AzureKeyVaultLinkedService withCredential(CredentialReference credential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -164,6 +163,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureKeyVaultLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultSecretReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultSecretReference.java
index e96c8c8368f1..c2e0883c8683 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultSecretReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureKeyVaultSecretReference.java
@@ -124,7 +124,6 @@ public AzureKeyVaultSecretReference withSecretVersion(Object secretVersion) {
*/
@Override
public void validate() {
- super.validate();
if (store() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLBatchExecutionActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLBatchExecutionActivity.java
index c25efa96ab97..b5b6910ae7db 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLBatchExecutionActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLBatchExecutionActivity.java
@@ -216,7 +216,6 @@ public AzureMLBatchExecutionActivity withWebServiceInputs(Map e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMLBatchExecutionActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLExecutePipelineActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLExecutePipelineActivity.java
index 9411b35e943f..505c9855beaa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLExecutePipelineActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLExecutePipelineActivity.java
@@ -347,7 +347,6 @@ public AzureMLExecutePipelineActivity withContinueOnStepFailure(Object continueO
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -355,6 +354,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model AzureMLExecutePipelineActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMLExecutePipelineActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLLinkedService.java
index 9de423c45547..3fe8daf7f633 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLLinkedService.java
@@ -305,7 +305,6 @@ public AzureMLLinkedService withAuthentication(Object authentication) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -313,6 +312,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMLLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLServiceLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLServiceLinkedService.java
index f4d72e446715..2aa50b3f6fb8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLServiceLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLServiceLinkedService.java
@@ -308,7 +308,6 @@ public AzureMLServiceLinkedService withEncryptedCredential(String encryptedCrede
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -316,6 +315,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMLServiceLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLUpdateResourceActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLUpdateResourceActivity.java
index c3260c0eb925..9ba22cad6fa7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLUpdateResourceActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMLUpdateResourceActivity.java
@@ -213,7 +213,6 @@ public AzureMLUpdateResourceActivity withTrainedModelFilePath(Object trainedMode
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -221,6 +220,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model AzureMLUpdateResourceActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMLUpdateResourceActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBLinkedService.java
index 3090c25136b4..5cddb8d1fb02 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBLinkedService.java
@@ -180,7 +180,6 @@ public AzureMariaDBLinkedService withEncryptedCredential(String encryptedCredent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMariaDBLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBSource.java
index a704e9b8a839..8ce75bab2835 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBSource.java
@@ -126,7 +126,6 @@ public AzureMariaDBSource withDisableMetricsCollection(Object disableMetricsColl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBTableDataset.java
index cfc08e2e36b1..cb67a40c9bca 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMariaDBTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public AzureMariaDBTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureMariaDBTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureMariaDBTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlLinkedService.java
index 8cc535568380..15fc6d298e10 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlLinkedService.java
@@ -180,7 +180,6 @@ public AzureMySqlLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMySqlLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSink.java
index 0127452a37ec..6c0a2f178160 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSink.java
@@ -126,7 +126,6 @@ public AzureMySqlSink withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSource.java
index 2790e8e0ff99..a5eca8b3155f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlSource.java
@@ -124,7 +124,6 @@ public AzureMySqlSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlTableDataset.java
index 753271bdb271..52611337cf03 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureMySqlTableDataset.java
@@ -175,7 +175,6 @@ public AzureMySqlTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -183,6 +182,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureMySqlTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureMySqlTableDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlLinkedService.java
index 2e28c589aa4d..1e1387cf7768 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlLinkedService.java
@@ -126,6 +126,271 @@ public AzurePostgreSqlLinkedService withConnectionString(Object connectionString
return this;
}
+ /**
+ * Get the server property: Server name for connection. Type: string.
+ *
+ * @return the server value.
+ */
+ public Object server() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().server();
+ }
+
+ /**
+ * Set the server property: Server name for connection. Type: string.
+ *
+ * @param server the server value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withServer(Object server) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withServer(server);
+ return this;
+ }
+
+ /**
+ * Get the port property: The port for the connection. Type: integer.
+ *
+ * @return the port value.
+ */
+ public Object port() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().port();
+ }
+
+ /**
+ * Set the port property: The port for the connection. Type: integer.
+ *
+ * @param port the port value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withPort(Object port) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withPort(port);
+ return this;
+ }
+
+ /**
+ * Get the username property: Username for authentication. Type: string.
+ *
+ * @return the username value.
+ */
+ public Object username() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().username();
+ }
+
+ /**
+ * Set the username property: Username for authentication. Type: string.
+ *
+ * @param username the username value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withUsername(Object username) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withUsername(username);
+ return this;
+ }
+
+ /**
+ * Get the database property: Database name for connection. Type: string.
+ *
+ * @return the database value.
+ */
+ public Object database() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().database();
+ }
+
+ /**
+ * Set the database property: Database name for connection. Type: string.
+ *
+ * @param database the database value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withDatabase(Object database) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withDatabase(database);
+ return this;
+ }
+
+ /**
+ * Get the sslMode property: SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4:
+ * verify-ca, 5: verify-full. Type: integer.
+ *
+ * @return the sslMode value.
+ */
+ public Object sslMode() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().sslMode();
+ }
+
+ /**
+ * Set the sslMode property: SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4:
+ * verify-ca, 5: verify-full. Type: integer.
+ *
+ * @param sslMode the sslMode value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withSslMode(Object sslMode) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withSslMode(sslMode);
+ return this;
+ }
+
+ /**
+ * Get the timeout property: The time to wait (in seconds) while trying to establish a connection before terminating
+ * the attempt and generating an error. Type: integer.
+ *
+ * @return the timeout value.
+ */
+ public Object timeout() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().timeout();
+ }
+
+ /**
+ * Set the timeout property: The time to wait (in seconds) while trying to establish a connection before terminating
+ * the attempt and generating an error. Type: integer.
+ *
+ * @param timeout the timeout value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withTimeout(Object timeout) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withTimeout(timeout);
+ return this;
+ }
+
+ /**
+ * Get the commandTimeout property: The time to wait (in seconds) while trying to execute a command before
+ * terminating the attempt and generating an error. Set to zero for infinity. Type: integer.
+ *
+ * @return the commandTimeout value.
+ */
+ public Object commandTimeout() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().commandTimeout();
+ }
+
+ /**
+ * Set the commandTimeout property: The time to wait (in seconds) while trying to execute a command before
+ * terminating the attempt and generating an error. Set to zero for infinity. Type: integer.
+ *
+ * @param commandTimeout the commandTimeout value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withCommandTimeout(Object commandTimeout) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withCommandTimeout(commandTimeout);
+ return this;
+ }
+
+ /**
+ * Get the trustServerCertificate property: Whether to trust the server certificate without validating it. Type:
+ * boolean.
+ *
+ * @return the trustServerCertificate value.
+ */
+ public Object trustServerCertificate() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().trustServerCertificate();
+ }
+
+ /**
+ * Set the trustServerCertificate property: Whether to trust the server certificate without validating it. Type:
+ * boolean.
+ *
+ * @param trustServerCertificate the trustServerCertificate value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withTrustServerCertificate(Object trustServerCertificate) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withTrustServerCertificate(trustServerCertificate);
+ return this;
+ }
+
+ /**
+ * Get the readBufferSize property: Determines the size of the internal buffer uses when reading. Increasing may
+ * improve performance if transferring large values from the database. Type: integer.
+ *
+ * @return the readBufferSize value.
+ */
+ public Object readBufferSize() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().readBufferSize();
+ }
+
+ /**
+ * Set the readBufferSize property: Determines the size of the internal buffer uses when reading. Increasing may
+ * improve performance if transferring large values from the database. Type: integer.
+ *
+ * @param readBufferSize the readBufferSize value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withReadBufferSize(Object readBufferSize) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withReadBufferSize(readBufferSize);
+ return this;
+ }
+
+ /**
+ * Get the timezone property: Gets or sets the session timezone. Type: string.
+ *
+ * @return the timezone value.
+ */
+ public Object timezone() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().timezone();
+ }
+
+ /**
+ * Set the timezone property: Gets or sets the session timezone. Type: string.
+ *
+ * @param timezone the timezone value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withTimezone(Object timezone) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withTimezone(timezone);
+ return this;
+ }
+
+ /**
+ * Get the encoding property: Gets or sets the .NET encoding that will be used to encode/decode PostgreSQL string
+ * data. Type: string.
+ *
+ * @return the encoding value.
+ */
+ public Object encoding() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().encoding();
+ }
+
+ /**
+ * Set the encoding property: Gets or sets the .NET encoding that will be used to encode/decode PostgreSQL string
+ * data. Type: string.
+ *
+ * @param encoding the encoding value to set.
+ * @return the AzurePostgreSqlLinkedService object itself.
+ */
+ public AzurePostgreSqlLinkedService withEncoding(Object encoding) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new AzurePostgreSqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withEncoding(encoding);
+ return this;
+ }
+
/**
* Get the password property: The Azure key vault secret reference of password in connection string.
*
@@ -181,7 +446,6 @@ public AzurePostgreSqlLinkedService withEncryptedCredential(String encryptedCred
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -189,6 +453,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzurePostgreSqlLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSink.java
index 6a0c41ee8e5a..ac49a64ee80e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSink.java
@@ -126,7 +126,6 @@ public AzurePostgreSqlSink withDisableMetricsCollection(Object disableMetricsCol
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSource.java
index 903e12771fa1..ba665bb74f49 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlSource.java
@@ -126,7 +126,6 @@ public AzurePostgreSqlSource withDisableMetricsCollection(Object disableMetricsC
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlTableDataset.java
index aee04ae66b8f..15cac3807381 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzurePostgreSqlTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,30 @@ public AzurePostgreSqlTableDataset withSchemaTypePropertiesSchema(Object schema)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzurePostgreSqlTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzurePostgreSqlTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureQueueSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureQueueSink.java
index de929ce0a408..7ad3d1b7edf7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureQueueSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureQueueSink.java
@@ -99,7 +99,6 @@ public AzureQueueSink withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexDataset.java
index 6133b503e8f9..3d4a16adebc1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexDataset.java
@@ -150,7 +150,6 @@ public AzureSearchIndexDataset withIndexName(Object indexName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -158,6 +157,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureSearchIndexDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureSearchIndexDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexSink.java
index a2992c67408b..309cc26ecefb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchIndexSink.java
@@ -124,7 +124,6 @@ public AzureSearchIndexSink withDisableMetricsCollection(Object disableMetricsCo
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchLinkedService.java
index b11f1c40d28f..3aa3da094e8d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSearchLinkedService.java
@@ -178,7 +178,6 @@ public AzureSearchLinkedService withEncryptedCredential(String encryptedCredenti
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -186,6 +185,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureSearchLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWLinkedService.java
index ba1cb8ed4dff..12ea89b99099 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWLinkedService.java
@@ -908,7 +908,6 @@ public AzureSqlDWLinkedService withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -916,6 +915,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureSqlDWLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWTableDataset.java
index e8a4d18f1443..5124974d8297 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDWTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,30 @@ public AzureSqlDWTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureSqlDWTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureSqlDWTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDatabaseLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDatabaseLinkedService.java
index 2b76745566dd..284a874ae70a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDatabaseLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlDatabaseLinkedService.java
@@ -933,7 +933,6 @@ public AzureSqlDatabaseLinkedService withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -941,6 +940,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureSqlDatabaseLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMILinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMILinkedService.java
index 0aabc9b904ba..f3445755b518 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMILinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMILinkedService.java
@@ -931,7 +931,6 @@ public AzureSqlMILinkedService withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -939,6 +938,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureSqlMILinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMITableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMITableDataset.java
index bfd1336740b2..bfabc96c627a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMITableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlMITableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,30 @@ public AzureSqlMITableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureSqlMITableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureSqlMITableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSink.java
index e7eee9242f29..94a62b53ec7b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSink.java
@@ -336,7 +336,6 @@ public AzureSqlSink withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
if (upsertSettings() != null) {
upsertSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSource.java
index d3085da25ed5..51835b638dcb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlSource.java
@@ -290,7 +290,6 @@ public AzureSqlSource withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlTableDataset.java
index e0f6130c11d1..71d18e566ad1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSqlTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,30 @@ public AzureSqlTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureSqlTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(AzureSqlTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureStorageLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureStorageLinkedService.java
index 4af6fc9e25b3..25c7f42a7f34 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureStorageLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureStorageLinkedService.java
@@ -228,7 +228,6 @@ public AzureStorageLinkedService withEncryptedCredential(String encryptedCredent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -236,6 +235,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureStorageLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSynapseArtifactsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSynapseArtifactsLinkedService.java
index 1f199dc828af..2b4f9a1080cb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSynapseArtifactsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureSynapseArtifactsLinkedService.java
@@ -185,7 +185,6 @@ public AzureSynapseArtifactsLinkedService withWorkspaceResourceId(Object workspa
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -193,6 +192,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureSynapseArtifactsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableDataset.java
index f67725680ac0..994ae32ca696 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableDataset.java
@@ -150,7 +150,6 @@ public AzureTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -158,6 +157,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model AzureTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureTableDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSink.java
index 85b16b5cdb0e..a63b70b720ec 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSink.java
@@ -207,7 +207,6 @@ public AzureTableSink withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSource.java
index caab34658790..dad1b7bdc715 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableSource.java
@@ -153,7 +153,6 @@ public AzureTableSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableStorageLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableStorageLinkedService.java
index dee22f518618..3b4c417c23e7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableStorageLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/AzureTableStorageLinkedService.java
@@ -277,7 +277,6 @@ public AzureTableStorageLinkedService withEncryptedCredential(String encryptedCr
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -285,6 +284,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(AzureTableStorageLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryDataset.java
index f90626cc26ae..bc35c87d2eaf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -170,12 +171,30 @@ public BinaryDataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(
+ new IllegalArgumentException("Missing required property linkedServiceName in model BinaryDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(BinaryDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryReadSettings.java
index 1fd740db6703..66a51443013e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinaryReadSettings.java
@@ -70,7 +70,6 @@ public BinaryReadSettings withCompressionProperties(CompressionReadSettings comp
*/
@Override
public void validate() {
- super.validate();
if (compressionProperties() != null) {
compressionProperties().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySink.java
index accc6687a0d8..cefaf7eed327 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySink.java
@@ -124,7 +124,6 @@ public BinarySink withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySource.java
index 26946eb81f63..5f4f33431125 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BinarySource.java
@@ -131,7 +131,6 @@ public BinarySource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobEventsTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobEventsTrigger.java
index f1bb5c49b7ab..b169d238f34f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobEventsTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobEventsTrigger.java
@@ -30,11 +30,6 @@ public final class BlobEventsTrigger extends MultiplePipelineTrigger {
*/
private BlobEventsTriggerTypeProperties innerTypeProperties = new BlobEventsTriggerTypeProperties();
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of BlobEventsTrigger class.
*/
@@ -60,17 +55,6 @@ private BlobEventsTriggerTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -228,7 +212,6 @@ public BlobEventsTrigger withScope(String scope) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -236,6 +219,9 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (pipelines() != null) {
+ pipelines().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(BlobEventsTrigger.class);
@@ -279,7 +265,7 @@ public static BlobEventsTrigger fromJson(JsonReader jsonReader) throws IOExcepti
if ("description".equals(fieldName)) {
deserializedBlobEventsTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedBlobEventsTrigger.runtimeState = TriggerRuntimeState.fromString(reader.getString());
+ deserializedBlobEventsTrigger.withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedBlobEventsTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSink.java
index ae0f5cdc84c9..7c0841c32e12 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSink.java
@@ -234,7 +234,6 @@ public BlobSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (metadata() != null) {
metadata().forEach(e -> e.validate());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSource.java
index cb2e66a15d99..ea56ebacfc51 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobSource.java
@@ -161,7 +161,6 @@ public BlobSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobTrigger.java
index b009180bd5fb..ad72556e7a71 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/BlobTrigger.java
@@ -30,11 +30,6 @@ public final class BlobTrigger extends MultiplePipelineTrigger {
*/
private BlobTriggerTypeProperties innerTypeProperties = new BlobTriggerTypeProperties();
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of BlobTrigger class.
*/
@@ -60,17 +55,6 @@ private BlobTriggerTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -174,7 +158,6 @@ public BlobTrigger withLinkedService(LinkedServiceReference linkedService) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(
@@ -182,6 +165,9 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (pipelines() != null) {
+ pipelines().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(BlobTrigger.class);
@@ -225,7 +211,7 @@ public static BlobTrigger fromJson(JsonReader jsonReader) throws IOException {
if ("description".equals(fieldName)) {
deserializedBlobTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedBlobTrigger.runtimeState = TriggerRuntimeState.fromString(reader.getString());
+ deserializedBlobTrigger.withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedBlobTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraLinkedService.java
index 0dd199707fff..05bac2a6b96a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraLinkedService.java
@@ -249,7 +249,6 @@ public CassandraLinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -257,6 +256,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CassandraLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraSource.java
index 35566c058cd8..5bb09655bf5b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraSource.java
@@ -161,7 +161,6 @@ public CassandraSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraTableDataset.java
index 68d99ff5d550..90f52a2dc3b1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CassandraTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -174,12 +175,30 @@ public CassandraTableDataset withKeyspace(Object keyspace) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model CassandraTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(CassandraTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ChainingTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ChainingTrigger.java
index e9642f432766..554d133b428a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ChainingTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ChainingTrigger.java
@@ -38,11 +38,6 @@ public final class ChainingTrigger extends Trigger {
*/
private ChainingTriggerTypeProperties innerTypeProperties = new ChainingTriggerTypeProperties();
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of ChainingTrigger class.
*/
@@ -88,17 +83,6 @@ private ChainingTriggerTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -170,7 +154,6 @@ public ChainingTrigger withRunDimension(String runDimension) {
*/
@Override
public void validate() {
- super.validate();
if (pipeline() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException("Missing required property pipeline in model ChainingTrigger"));
@@ -227,7 +210,7 @@ public static ChainingTrigger fromJson(JsonReader jsonReader) throws IOException
if ("description".equals(fieldName)) {
deserializedChainingTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedChainingTrigger.runtimeState = TriggerRuntimeState.fromString(reader.getString());
+ deserializedChainingTrigger.withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedChainingTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CmdkeySetup.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CmdkeySetup.java
index 7bc36097c229..270a80016abe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CmdkeySetup.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CmdkeySetup.java
@@ -128,7 +128,6 @@ public CmdkeySetup withPassword(SecretBase password) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsEntityDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsEntityDataset.java
index f9dae7b68f46..f9be1bb37255 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsEntityDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsEntityDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public CommonDataServiceForAppsEntityDataset withEntityName(Object entityName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model CommonDataServiceForAppsEntityDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(CommonDataServiceForAppsEntityDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsLinkedService.java
index 8a81af343a14..db466737d9db 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsLinkedService.java
@@ -448,7 +448,6 @@ public CommonDataServiceForAppsLinkedService withEncryptedCredential(String encr
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -456,6 +455,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CommonDataServiceForAppsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSink.java
index f9bf70fabe3d..3f32d5c544e1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSink.java
@@ -181,7 +181,6 @@ public CommonDataServiceForAppsSink withDisableMetricsCollection(Object disableM
*/
@Override
public void validate() {
- super.validate();
if (writeBehavior() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSource.java
index 63e7f7a98e9e..d20dece9e63f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CommonDataServiceForAppsSource.java
@@ -137,7 +137,6 @@ public CommonDataServiceForAppsSource withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ComponentSetup.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ComponentSetup.java
index 754e8a58ce31..814dfcb7f605 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ComponentSetup.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ComponentSetup.java
@@ -105,7 +105,6 @@ public ComponentSetup withLicenseKey(SecretBase licenseKey) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurLinkedService.java
index 8f35344918f5..fa93f869f709 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurLinkedService.java
@@ -301,7 +301,6 @@ public ConcurLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -309,6 +308,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ConcurLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurObjectDataset.java
index 90e7c4eeab85..9c7b83424701 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public ConcurObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ConcurObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ConcurObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurSource.java
index 0cf89b089f7b..955da0a95177 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ConcurSource.java
@@ -126,7 +126,6 @@ public ConcurSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ControlActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ControlActivity.java
index b9903066b4a1..1761e6cb15aa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ControlActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ControlActivity.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -100,9 +101,20 @@ public ControlActivity withUserProperties(List userProperties) {
*/
@Override
public void validate() {
- super.validate();
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model ControlActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ControlActivity.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopyActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopyActivity.java
index 14e242a7406d..d51febf07754 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopyActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopyActivity.java
@@ -544,7 +544,6 @@ public CopyActivity withSkipErrorFile(SkipErrorFile skipErrorFile) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -558,6 +557,22 @@ public void validate() {
if (outputs() != null) {
outputs().forEach(e -> e.validate());
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model CopyActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CopyActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopySink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopySink.java
index b8205018c528..a771d228461b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopySink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CopySink.java
@@ -308,6 +308,8 @@ public static CopySink fromJson(JsonReader jsonReader) throws IOException {
return ParquetSink.fromJson(readerToUse.reset());
} else if ("BinarySink".equals(discriminatorValue)) {
return BinarySink.fromJson(readerToUse.reset());
+ } else if ("IcebergSink".equals(discriminatorValue)) {
+ return IcebergSink.fromJson(readerToUse.reset());
} else if ("BlobSink".equals(discriminatorValue)) {
return BlobSink.fromJson(readerToUse.reset());
} else if ("FileSystemSink".equals(discriminatorValue)) {
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbLinkedService.java
index a99102e6bd24..5198d707e3bb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbLinkedService.java
@@ -407,7 +407,6 @@ public CosmosDbLinkedService withCredential(CredentialReference credential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -415,6 +414,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CosmosDbLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiCollectionDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiCollectionDataset.java
index 5704355290fb..2a2ce3350173 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiCollectionDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiCollectionDataset.java
@@ -151,7 +151,6 @@ public CosmosDbMongoDbApiCollectionDataset withCollection(Object collection) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -159,6 +158,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model CosmosDbMongoDbApiCollectionDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CosmosDbMongoDbApiCollectionDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiLinkedService.java
index 39581470fbd8..b1a15b40f817 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiLinkedService.java
@@ -183,7 +183,6 @@ public CosmosDbMongoDbApiLinkedService withDatabase(Object database) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -191,6 +190,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CosmosDbMongoDbApiLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSink.java
index 08a47c009d0d..2cb5180d9d68 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSink.java
@@ -130,7 +130,6 @@ public CosmosDbMongoDbApiSink withDisableMetricsCollection(Object disableMetrics
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSource.java
index 3f319408b95c..b17d2d38c038 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbMongoDbApiSource.java
@@ -225,7 +225,6 @@ public CosmosDbMongoDbApiSource withDisableMetricsCollection(Object disableMetri
*/
@Override
public void validate() {
- super.validate();
if (cursorMethods() != null) {
cursorMethods().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiCollectionDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiCollectionDataset.java
index 1b228d0139d0..2b6fd31fe90c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiCollectionDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiCollectionDataset.java
@@ -151,7 +151,6 @@ public CosmosDbSqlApiCollectionDataset withCollectionName(Object collectionName)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -159,6 +158,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model CosmosDbSqlApiCollectionDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CosmosDbSqlApiCollectionDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSink.java
index eafdaa294c1a..64f1c6e43a38 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSink.java
@@ -127,7 +127,6 @@ public CosmosDbSqlApiSink withDisableMetricsCollection(Object disableMetricsColl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSource.java
index db4d3769dc71..4516b23e46ce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CosmosDbSqlApiSource.java
@@ -213,7 +213,6 @@ public CosmosDbSqlApiSource withDisableMetricsCollection(Object disableMetricsCo
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseLinkedService.java
index 367ad448049b..dd20990b21cb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseLinkedService.java
@@ -180,7 +180,6 @@ public CouchbaseLinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CouchbaseLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseSource.java
index 3b83054d25e1..fbc83d1000e5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseSource.java
@@ -126,7 +126,6 @@ public CouchbaseSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseTableDataset.java
index e94a9b171d65..02d1e4791e8f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CouchbaseTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public CouchbaseTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model CouchbaseTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(CouchbaseTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomActivity.java
index 9b37846fa5c4..3b59dea4867c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomActivity.java
@@ -303,7 +303,6 @@ public CustomActivity withAutoUserSpecification(Object autoUserSpecification) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -311,6 +310,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model CustomActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CustomActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataSourceLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataSourceLinkedService.java
index 9e5205a4fb66..f3497f63b735 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataSourceLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataSourceLinkedService.java
@@ -117,12 +117,21 @@ public CustomDataSourceLinkedService withAnnotations(List annotations) {
*/
@Override
public void validate() {
- super.validate();
if (typeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
"Missing required property typeProperties in model CustomDataSourceLinkedService"));
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CustomDataSourceLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataset.java
index fe886306da4c..1d8d5bd312ce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -134,9 +135,27 @@ public CustomDataset withFolder(DatasetFolder folder) {
*/
@Override
public void validate() {
- super.validate();
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(
+ new IllegalArgumentException("Missing required property linkedServiceName in model CustomDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(CustomDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomEventsTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomEventsTrigger.java
index 0b13856d77c4..0a5c7c194b20 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomEventsTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/CustomEventsTrigger.java
@@ -30,11 +30,6 @@ public final class CustomEventsTrigger extends MultiplePipelineTrigger {
*/
private CustomEventsTriggerTypeProperties innerTypeProperties = new CustomEventsTriggerTypeProperties();
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of CustomEventsTrigger class.
*/
@@ -60,17 +55,6 @@ private CustomEventsTriggerTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -201,7 +185,6 @@ public CustomEventsTrigger withScope(String scope) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -209,6 +192,9 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (pipelines() != null) {
+ pipelines().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(CustomEventsTrigger.class);
@@ -252,7 +238,8 @@ public static CustomEventsTrigger fromJson(JsonReader jsonReader) throws IOExcep
if ("description".equals(fieldName)) {
deserializedCustomEventsTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedCustomEventsTrigger.runtimeState = TriggerRuntimeState.fromString(reader.getString());
+ deserializedCustomEventsTrigger
+ .withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedCustomEventsTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowDebugResource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowDebugResource.java
index ccd6754779f7..851e90c9c669 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowDebugResource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowDebugResource.java
@@ -63,7 +63,6 @@ public DataFlowDebugResource withName(String name) {
*/
@Override
public void validate() {
- super.validate();
if (properties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSink.java
index 68c4e15cb284..a9bd81b55f01 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSink.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -123,15 +124,29 @@ public DataFlowSink withFlowlet(DataFlowReference flowlet) {
*/
@Override
public void validate() {
- super.validate();
if (schemaLinkedService() != null) {
schemaLinkedService().validate();
}
if (rejectedDataLinkedService() != null) {
rejectedDataLinkedService().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model DataFlowSink"));
+ }
+ if (dataset() != null) {
+ dataset().validate();
+ }
+ if (linkedService() != null) {
+ linkedService().validate();
+ }
+ if (flowlet() != null) {
+ flowlet().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(DataFlowSink.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSource.java
index e8da7950d3ea..cd9dc729a2ca 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataFlowSource.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -98,12 +99,26 @@ public DataFlowSource withFlowlet(DataFlowReference flowlet) {
*/
@Override
public void validate() {
- super.validate();
if (schemaLinkedService() != null) {
schemaLinkedService().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model DataFlowSource"));
+ }
+ if (dataset() != null) {
+ dataset().validate();
+ }
+ if (linkedService() != null) {
+ linkedService().validate();
+ }
+ if (flowlet() != null) {
+ flowlet().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(DataFlowSource.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataLakeAnalyticsUsqlActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataLakeAnalyticsUsqlActivity.java
index 3de87c01bc9b..36436a23643d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataLakeAnalyticsUsqlActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DataLakeAnalyticsUsqlActivity.java
@@ -308,7 +308,6 @@ public DataLakeAnalyticsUsqlActivity withCompilationMode(Object compilationMode)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -316,6 +315,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model DataLakeAnalyticsUsqlActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DataLakeAnalyticsUsqlActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksNotebookActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksNotebookActivity.java
index 2405a70c29af..a85f1be7a21f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksNotebookActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksNotebookActivity.java
@@ -208,7 +208,6 @@ public DatabricksNotebookActivity withLibraries(List> librar
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -216,6 +215,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(
+ new IllegalArgumentException("Missing required property name in model DatabricksNotebookActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DatabricksNotebookActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkJarActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkJarActivity.java
index 8fef739723b8..8f18dc9b8413 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkJarActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkJarActivity.java
@@ -206,7 +206,6 @@ public DatabricksSparkJarActivity withLibraries(List> librar
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -214,6 +213,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(
+ new IllegalArgumentException("Missing required property name in model DatabricksSparkJarActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DatabricksSparkJarActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkPythonActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkPythonActivity.java
index 0d22b6992e91..2aa46e89d277 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkPythonActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatabricksSparkPythonActivity.java
@@ -206,7 +206,6 @@ public DatabricksSparkPythonActivity withLibraries(List> lib
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -214,6 +213,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model DatabricksSparkPythonActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DatabricksSparkPythonActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Dataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Dataset.java
index 0bed202f73a3..7624d73bf4f4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Dataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Dataset.java
@@ -343,6 +343,8 @@ public static Dataset fromJson(JsonReader jsonReader) throws IOException {
return OrcDataset.fromJson(readerToUse.reset());
} else if ("Binary".equals(discriminatorValue)) {
return BinaryDataset.fromJson(readerToUse.reset());
+ } else if ("Iceberg".equals(discriminatorValue)) {
+ return IcebergDataset.fromJson(readerToUse.reset());
} else if ("AzureBlob".equals(discriminatorValue)) {
return AzureBlobDataset.fromJson(readerToUse.reset());
} else if ("AzureTable".equals(discriminatorValue)) {
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetDebugResource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetDebugResource.java
index 8720bf0f9956..94a3ddd1d940 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetDebugResource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetDebugResource.java
@@ -63,7 +63,6 @@ public DatasetDebugResource withName(String name) {
*/
@Override
public void validate() {
- super.validate();
if (properties() == null) {
throw LOGGER.atError()
.log(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetReference.java
index d80a1f467041..162ab7a945e8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DatasetReference.java
@@ -21,7 +21,7 @@ public final class DatasetReference implements JsonSerializable {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DataworldLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2LinkedService.java
index 7dc49b6ba554..b50e73d804d1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2LinkedService.java
@@ -334,7 +334,6 @@ public Db2LinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -342,6 +341,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(Db2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2Source.java
index aae51e584aa5..398faee7af3e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2Source.java
@@ -124,7 +124,6 @@ public Db2Source withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2TableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2TableDataset.java
index 7114c1ed372d..ffa23e4eba47 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2TableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Db2TableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public Db2TableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model Db2TableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(Db2TableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DeleteActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DeleteActivity.java
index 21fd91376dcd..5ee4f593c227 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DeleteActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DeleteActivity.java
@@ -278,7 +278,6 @@ public DeleteActivity withStoreSettings(StoreReadSettings storeSettings) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -286,6 +285,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model DeleteActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DeleteActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextDataset.java
index dcb3992703cb..57eca620cf80 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -366,12 +367,30 @@ public DelimitedTextDataset withNullValue(Object nullValue) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model DelimitedTextDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(DelimitedTextDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextReadSettings.java
index 6bcb061c6f4f..cfe008423bb6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextReadSettings.java
@@ -98,7 +98,6 @@ public DelimitedTextReadSettings withCompressionProperties(CompressionReadSettin
*/
@Override
public void validate() {
- super.validate();
if (compressionProperties() != null) {
compressionProperties().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSink.java
index d3662c9dfdfe..6ca362689531 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSink.java
@@ -149,7 +149,6 @@ public DelimitedTextSink withDisableMetricsCollection(Object disableMetricsColle
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSource.java
index 41c8fbb211f8..2b4ee457a16a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextSource.java
@@ -159,7 +159,6 @@ public DelimitedTextSource withDisableMetricsCollection(Object disableMetricsCol
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextWriteSettings.java
index 9921880498f7..e5d035a9d15c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DelimitedTextWriteSettings.java
@@ -159,7 +159,6 @@ public DelimitedTextWriteSettings withFileNamePrefix(Object fileNamePrefix) {
*/
@Override
public void validate() {
- super.validate();
if (fileExtension() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionDataset.java
index 40b6c6020152..c2d699dee69b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionDataset.java
@@ -151,7 +151,6 @@ public DocumentDbCollectionDataset withCollectionName(Object collectionName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -159,6 +158,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model DocumentDbCollectionDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DocumentDbCollectionDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSink.java
index 554daa03b631..ef33d462194f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSink.java
@@ -154,7 +154,6 @@ public DocumentDbCollectionSink withDisableMetricsCollection(Object disableMetri
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSource.java
index 180473aa352d..5897f685a935 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DocumentDbCollectionSource.java
@@ -189,7 +189,6 @@ public DocumentDbCollectionSource withDisableMetricsCollection(Object disableMet
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillLinkedService.java
index f371afea83e0..2ce35026cb02 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillLinkedService.java
@@ -180,7 +180,6 @@ public DrillLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DrillLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillSource.java
index 398ab23d2a7c..b4783c6496b6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillSource.java
@@ -126,7 +126,6 @@ public DrillSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillTableDataset.java
index e31614344402..e428cd0ba8e4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DrillTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public DrillTableDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model DrillTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(DrillTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXLinkedService.java
index 48de8a119b82..3ad78cc70179 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXLinkedService.java
@@ -259,7 +259,6 @@ public DynamicsAXLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -267,6 +266,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DynamicsAXLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXResourceDataset.java
index 33cbddc935bc..5b30f15647b0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXResourceDataset.java
@@ -150,7 +150,6 @@ public DynamicsAXResourceDataset withPath(Object path) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -158,6 +157,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model DynamicsAXResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DynamicsAXResourceDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXSource.java
index 270ecd51945b..4fcde0ccbcd9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsAXSource.java
@@ -157,7 +157,6 @@ public DynamicsAXSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmEntityDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmEntityDataset.java
index 08412809bc9f..2bd038cd70c1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmEntityDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmEntityDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public DynamicsCrmEntityDataset withEntityName(Object entityName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model DynamicsCrmEntityDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(DynamicsCrmEntityDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmLinkedService.java
index 7da05bc0cc19..73a15f2b50ac 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmLinkedService.java
@@ -467,7 +467,6 @@ public DynamicsCrmLinkedService withEncryptedCredential(String encryptedCredenti
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -475,6 +474,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DynamicsCrmLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSink.java
index 66254998d062..7de430e49545 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSink.java
@@ -181,7 +181,6 @@ public DynamicsCrmSink withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
if (writeBehavior() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException("Missing required property writeBehavior in model DynamicsCrmSink"));
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSource.java
index 707a11dcb6cf..ff137fc3c6da 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsCrmSource.java
@@ -137,7 +137,6 @@ public DynamicsCrmSource withDisableMetricsCollection(Object disableMetricsColle
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsEntityDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsEntityDataset.java
index 89ac1dac2841..4fa06c50cc2b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsEntityDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsEntityDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public DynamicsEntityDataset withEntityName(Object entityName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model DynamicsEntityDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(DynamicsEntityDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsLinkedService.java
index 0e2248533ba8..06787a50e406 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsLinkedService.java
@@ -465,7 +465,6 @@ public DynamicsLinkedService withCredential(CredentialReference credential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -473,6 +472,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(DynamicsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSink.java
index 99a501e73537..5c9908f0494b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSink.java
@@ -181,7 +181,6 @@ public DynamicsSink withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
if (writeBehavior() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException("Missing required property writeBehavior in model DynamicsSink"));
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSource.java
index e6fbac61d9a0..1f2cdf466ee9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/DynamicsSource.java
@@ -137,7 +137,6 @@ public DynamicsSource withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaLinkedService.java
index 5f8d265d9bdc..f9dc95aefdf7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaLinkedService.java
@@ -278,7 +278,6 @@ public EloquaLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -286,6 +285,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(EloquaLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaObjectDataset.java
index 41561fd932e5..8a52e29799b8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public EloquaObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model EloquaObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(EloquaObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaSource.java
index f498eeb3b7d3..047738fee347 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EloquaSource.java
@@ -126,7 +126,6 @@ public EloquaSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EnvironmentVariableSetup.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EnvironmentVariableSetup.java
index 82993539d24d..10ad6eaf9779 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EnvironmentVariableSetup.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/EnvironmentVariableSetup.java
@@ -105,7 +105,6 @@ public EnvironmentVariableSetup withVariableValue(String variableValue) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelDataset.java
index d9ed8ae2707c..c9e845afe9ef 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -291,12 +292,29 @@ public ExcelDataset withNullValue(Object nullValue) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property linkedServiceName in model ExcelDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ExcelDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelSource.java
index 58f1c38221aa..528d97a8207d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExcelSource.java
@@ -134,7 +134,6 @@ public ExcelSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteDataFlowActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteDataFlowActivity.java
index d12da590a9f6..d549febf0f33 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteDataFlowActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteDataFlowActivity.java
@@ -349,7 +349,6 @@ public ExecuteDataFlowActivity withSourceStagingConcurrency(Object sourceStaging
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -357,6 +356,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model ExecuteDataFlowActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ExecuteDataFlowActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutePipelineActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutePipelineActivity.java
index 5b87220b83f8..8938aaa02147 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutePipelineActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutePipelineActivity.java
@@ -212,7 +212,6 @@ public ExecutePipelineActivity withWaitOnCompletion(Boolean waitOnCompletion) {
*/
@Override
public void validate() {
- super.validate();
if (policy() != null) {
policy().validate();
}
@@ -223,6 +222,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model ExecutePipelineActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ExecutePipelineActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteSsisPackageActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteSsisPackageActivity.java
index 9232f7733475..90591919e9ce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteSsisPackageActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteSsisPackageActivity.java
@@ -419,7 +419,6 @@ public ExecuteSsisPackageActivity withLogLocation(SsisLogLocation logLocation) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -427,6 +426,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(
+ new IllegalArgumentException("Missing required property name in model ExecuteSsisPackageActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ExecuteSsisPackageActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteWranglingDataflowActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteWranglingDataflowActivity.java
index ec2d911a3099..0d07097e9c2c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteWranglingDataflowActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecuteWranglingDataflowActivity.java
@@ -405,7 +405,6 @@ public ExecuteWranglingDataflowActivity withSourceStagingConcurrency(Object sour
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -416,6 +415,17 @@ public void validate() {
if (policy() != null) {
policy().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model ExecuteWranglingDataflowActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ExecuteWranglingDataflowActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutionActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutionActivity.java
index 3671ea39dce4..90f11197a26a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutionActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ExecutionActivity.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -150,15 +151,26 @@ public ExecutionActivity withUserProperties(List userProperties) {
*/
@Override
public void validate() {
- super.validate();
if (linkedServiceName() != null) {
linkedServiceName().validate();
}
if (policy() != null) {
policy().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model ExecutionActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ExecutionActivity.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Expression.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Expression.java
index 79e1ed7ffd03..7d3f4fcbef20 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Expression.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Expression.java
@@ -20,7 +20,7 @@ public final class Expression implements JsonSerializable {
/*
* Expression type.
*/
- private String type = "Expression";
+ private final String type = "Expression";
/*
* Expression value.
@@ -42,17 +42,6 @@ public String type() {
return this.type;
}
- /**
- * Set the type property: Expression type.
- *
- * @param type the type value to set.
- * @return the Expression object itself.
- */
- public Expression withType(String type) {
- this.type = type;
- return this;
- }
-
/**
* Get the value property: Expression value.
*
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryGitHubConfiguration.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryGitHubConfiguration.java
index 4e28b2610a00..b0fdd4a1149d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryGitHubConfiguration.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryGitHubConfiguration.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -172,12 +173,33 @@ public FactoryGitHubConfiguration withDisablePublish(Boolean disablePublish) {
*/
@Override
public void validate() {
- super.validate();
if (clientSecret() != null) {
clientSecret().validate();
}
+ if (accountName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property accountName in model FactoryGitHubConfiguration"));
+ }
+ if (repositoryName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property repositoryName in model FactoryGitHubConfiguration"));
+ }
+ if (collaborationBranch() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property collaborationBranch in model FactoryGitHubConfiguration"));
+ }
+ if (rootFolder() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property rootFolder in model FactoryGitHubConfiguration"));
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(FactoryGitHubConfiguration.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryVstsConfiguration.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryVstsConfiguration.java
index 8874e5ad29df..839205975933 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryVstsConfiguration.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FactoryVstsConfiguration.java
@@ -148,12 +148,31 @@ public FactoryVstsConfiguration withDisablePublish(Boolean disablePublish) {
*/
@Override
public void validate() {
- super.validate();
if (projectName() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
"Missing required property projectName in model FactoryVstsConfiguration"));
}
+ if (accountName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property accountName in model FactoryVstsConfiguration"));
+ }
+ if (repositoryName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property repositoryName in model FactoryVstsConfiguration"));
+ }
+ if (collaborationBranch() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property collaborationBranch in model FactoryVstsConfiguration"));
+ }
+ if (rootFolder() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property rootFolder in model FactoryVstsConfiguration"));
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(FactoryVstsConfiguration.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FailActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FailActivity.java
index 5790ae13e9fc..e2c09986962f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FailActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FailActivity.java
@@ -171,7 +171,6 @@ public FailActivity withErrorCode(Object errorCode) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -179,6 +178,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model FailActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(FailActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLinkedService.java
index 560ffb04afda..c4ce2a11d58b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLinkedService.java
@@ -201,7 +201,6 @@ public FileServerLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -209,6 +208,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(FileServerLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLocation.java
index bed010ba9128..cdf3f265707f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerLocation.java
@@ -63,7 +63,6 @@ public FileServerLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerReadSettings.java
index 2a1a8966ec13..472c4fc74e3d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerReadSettings.java
@@ -337,7 +337,6 @@ public FileServerReadSettings withDisableMetricsCollection(Object disableMetrics
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerWriteSettings.java
index 95f93c276077..6fc34a5680f0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileServerWriteSettings.java
@@ -82,7 +82,9 @@ public FileServerWriteSettings withMetadata(List metadata) {
*/
@Override
public void validate() {
- super.validate();
+ if (metadata() != null) {
+ metadata().forEach(e -> e.validate());
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileShareDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileShareDataset.java
index b3355f7434a5..2c7695300924 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileShareDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileShareDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -295,12 +296,30 @@ public FileShareDataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model FileShareDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(FileShareDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSink.java
index a8fa36970720..f72003b7b3b7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSink.java
@@ -124,7 +124,6 @@ public FileSystemSink withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSource.java
index 2624e6c43fb7..adc01df2a27d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FileSystemSource.java
@@ -137,7 +137,6 @@ public FileSystemSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FilterActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FilterActivity.java
index 585471f7b536..5c7c676377d9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FilterActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FilterActivity.java
@@ -162,7 +162,6 @@ public FilterActivity withCondition(Expression condition) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -170,6 +169,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model FilterActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(FilterActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Flowlet.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Flowlet.java
index 1b61da905ec3..1a3598f39b2d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Flowlet.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Flowlet.java
@@ -201,10 +201,12 @@ public Flowlet withScriptLines(List scriptLines) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (folder() != null) {
+ folder().validate();
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ForEachActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ForEachActivity.java
index 9df0306e2743..e3abf5c5b604 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ForEachActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ForEachActivity.java
@@ -210,7 +210,6 @@ public ForEachActivity withActivities(List activities) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -218,6 +217,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model ForEachActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ForEachActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FormatWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FormatWriteSettings.java
index 03a951863f88..2e4f53b85dd8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FormatWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FormatWriteSettings.java
@@ -120,6 +120,8 @@ public static FormatWriteSettings fromJson(JsonReader jsonReader) throws IOExcep
return DelimitedTextWriteSettings.fromJson(readerToUse.reset());
} else if ("JsonWriteSettings".equals(discriminatorValue)) {
return JsonWriteSettings.fromJson(readerToUse.reset());
+ } else if ("IcebergWriteSettings".equals(discriminatorValue)) {
+ return IcebergWriteSettings.fromJson(readerToUse.reset());
} else {
return fromJsonKnownDiscriminator(readerToUse.reset());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpReadSettings.java
index 83d9f5668253..f4914c1c887b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpReadSettings.java
@@ -307,7 +307,6 @@ public FtpReadSettings withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLinkedService.java
index a9a4872f5f28..b54e18259fa5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLinkedService.java
@@ -301,7 +301,6 @@ public FtpServerLinkedService withEnableServerCertificateValidation(Object enabl
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -309,6 +308,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(FtpServerLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLocation.java
index 1692214eb059..9e906b3fc48c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/FtpServerLocation.java
@@ -63,7 +63,6 @@ public FtpServerLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GetMetadataActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GetMetadataActivity.java
index 687f31acf661..213c5e775aba 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GetMetadataActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GetMetadataActivity.java
@@ -226,7 +226,6 @@ public GetMetadataActivity withFormatSettings(FormatReadSettings formatSettings)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -234,6 +233,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model GetMetadataActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(GetMetadataActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsLinkedService.java
index bd7e0690358b..038006c1da4b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsLinkedService.java
@@ -518,7 +518,6 @@ public GoogleAdWordsLinkedService withEncryptedCredential(String encryptedCreden
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -526,6 +525,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(GoogleAdWordsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsObjectDataset.java
index c71c2e7f8991..65607275ee56 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public GoogleAdWordsObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model GoogleAdWordsObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(GoogleAdWordsObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsSource.java
index 17f0ba430e8e..629856a72d71 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleAdWordsSource.java
@@ -126,7 +126,6 @@ public GoogleAdWordsSource withDisableMetricsCollection(Object disableMetricsCol
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryLinkedService.java
index a4af9985c64b..b95fe3e1037a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryLinkedService.java
@@ -410,7 +410,6 @@ public GoogleBigQueryLinkedService withEncryptedCredential(String encryptedCrede
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -418,6 +417,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(GoogleBigQueryLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryObjectDataset.java
index 4bbf2cdac45d..cbdbfc7262da 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,30 @@ public GoogleBigQueryObjectDataset withDataset(Object dataset) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model GoogleBigQueryObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(GoogleBigQueryObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQuerySource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQuerySource.java
index 894811f26bfd..d95b6aaaa20c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQuerySource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQuerySource.java
@@ -126,7 +126,6 @@ public GoogleBigQuerySource withDisableMetricsCollection(Object disableMetricsCo
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2LinkedService.java
index 1d66860aca96..9fc205c2d927 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2LinkedService.java
@@ -279,7 +279,6 @@ public GoogleBigQueryV2LinkedService withEncryptedCredential(String encryptedCre
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -287,6 +286,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(GoogleBigQueryV2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2ObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2ObjectDataset.java
index 4928489b135a..233d53549f44 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2ObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2ObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -174,12 +175,30 @@ public GoogleBigQueryV2ObjectDataset withDataset(Object dataset) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model GoogleBigQueryV2ObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(GoogleBigQueryV2ObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2Source.java
index a6bfa3475de9..b752b6a3b862 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleBigQueryV2Source.java
@@ -126,7 +126,6 @@ public GoogleBigQueryV2Source withDisableMetricsCollection(Object disableMetrics
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLinkedService.java
index 87f2c15a5db1..6d36199e84ce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLinkedService.java
@@ -210,7 +210,6 @@ public GoogleCloudStorageLinkedService withEncryptedCredential(String encryptedC
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -218,6 +217,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(GoogleCloudStorageLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLocation.java
index dc6b6c2d7ce8..d57a6fe7e1be 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageLocation.java
@@ -117,7 +117,6 @@ public GoogleCloudStorageLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageReadSettings.java
index 34d0ab8c1cc4..af0b78bb88a5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleCloudStorageReadSettings.java
@@ -336,7 +336,6 @@ public GoogleCloudStorageReadSettings withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleSheetsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleSheetsLinkedService.java
index ca9bb8aa4cdb..130e1566d34d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleSheetsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GoogleSheetsLinkedService.java
@@ -155,7 +155,6 @@ public GoogleSheetsLinkedService withEncryptedCredential(String encryptedCredent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -163,6 +162,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(GoogleSheetsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumLinkedService.java
index c18652c711b1..1813b541bd91 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumLinkedService.java
@@ -180,7 +180,6 @@ public GreenplumLinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(GreenplumLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumSource.java
index 1fdf10c25312..9c2a5a1519ad 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumSource.java
@@ -126,7 +126,6 @@ public GreenplumSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumTableDataset.java
index 814b79a55b99..9e8d001d573b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/GreenplumTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public GreenplumTableDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model GreenplumTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(GreenplumTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseLinkedService.java
index db3ea4e84b8f..704abcb2c6d4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseLinkedService.java
@@ -376,7 +376,6 @@ public HBaseLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -384,6 +383,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HBaseLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseObjectDataset.java
index 86211dc0b0c9..0be93a694bf3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public HBaseObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model HBaseObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(HBaseObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseSource.java
index 2619287419bb..5d5490d737a9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HBaseSource.java
@@ -126,7 +126,6 @@ public HBaseSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightHiveActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightHiveActivity.java
index 3ba1844f5285..0f118da54969 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightHiveActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightHiveActivity.java
@@ -320,7 +320,6 @@ public HDInsightHiveActivity withQueryTimeout(Integer queryTimeout) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -328,6 +327,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model HDInsightHiveActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HDInsightHiveActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightLinkedService.java
index 1ac12144d7b5..59d67c24d097 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightLinkedService.java
@@ -299,7 +299,6 @@ public HDInsightLinkedService withFileSystem(Object fileSystem) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -307,6 +306,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HDInsightLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightMapReduceActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightMapReduceActivity.java
index 7f457e922208..36f441c838c1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightMapReduceActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightMapReduceActivity.java
@@ -319,7 +319,6 @@ public HDInsightMapReduceActivity withDefines(Map defines) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -327,6 +326,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(
+ new IllegalArgumentException("Missing required property name in model HDInsightMapReduceActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HDInsightMapReduceActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightOnDemandLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightOnDemandLinkedService.java
index c5f53f15bdb1..c3f0d6b904fa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightOnDemandLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightOnDemandLinkedService.java
@@ -946,7 +946,6 @@ public HDInsightOnDemandLinkedService withCredential(CredentialReference credent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -954,6 +953,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HDInsightOnDemandLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightPigActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightPigActivity.java
index c544e5ff1882..316e8dc6ae7f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightPigActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightPigActivity.java
@@ -274,7 +274,6 @@ public HDInsightPigActivity withDefines(Map defines) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -282,6 +281,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model HDInsightPigActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HDInsightPigActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightSparkActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightSparkActivity.java
index 18378d99ee2f..1b884f39f984 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightSparkActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightSparkActivity.java
@@ -326,7 +326,6 @@ public HDInsightSparkActivity withSparkConfig(Map sparkConfig) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -334,6 +333,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model HDInsightSparkActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HDInsightSparkActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightStreamingActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightStreamingActivity.java
index b21d28438d02..2e74fd009ed5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightStreamingActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HDInsightStreamingActivity.java
@@ -411,7 +411,6 @@ public HDInsightStreamingActivity withDefines(Map defines) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -419,6 +418,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(
+ new IllegalArgumentException("Missing required property name in model HDInsightStreamingActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HDInsightStreamingActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLinkedService.java
index 479197cb1c9c..7f60b73db13a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLinkedService.java
@@ -230,7 +230,6 @@ public HdfsLinkedService withPassword(SecretBase password) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -238,6 +237,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HdfsLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLocation.java
index d3f12d043dd4..bf8349d06508 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsLocation.java
@@ -63,7 +63,6 @@ public HdfsLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsReadSettings.java
index 504a7ebc0221..8cc029e01b9f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsReadSettings.java
@@ -332,7 +332,6 @@ public HdfsReadSettings withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
if (distcpSettings() != null) {
distcpSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsSource.java
index cb9086c30b6e..0e6245d2351a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HdfsSource.java
@@ -134,7 +134,6 @@ public HdfsSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (distcpSettings() != null) {
distcpSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveLinkedService.java
index 06c406715b58..0d663e31a194 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveLinkedService.java
@@ -516,7 +516,6 @@ public HiveLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -524,6 +523,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HiveLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveObjectDataset.java
index cbf48beaea56..cdf04843cf89 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public HiveObjectDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model HiveObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(HiveObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveSource.java
index 95cc03cb773a..281bc3d25888 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HiveSource.java
@@ -126,7 +126,6 @@ public HiveSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpDataset.java
index 1d8f39216c25..2edc12444fc0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -272,12 +273,29 @@ public HttpDataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property linkedServiceName in model HttpDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(HttpDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpLinkedService.java
index db50f2e0abc0..a17a8be89e27 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpLinkedService.java
@@ -336,7 +336,6 @@ public HttpLinkedService withEnableServerCertificateValidation(Object enableServ
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -344,6 +343,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HttpLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpReadSettings.java
index 0583b093e9dc..7ee9aff92f82 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpReadSettings.java
@@ -203,7 +203,6 @@ public HttpReadSettings withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpServerLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpServerLocation.java
index 4d2a5570dba2..a4b60474da60 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpServerLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpServerLocation.java
@@ -90,7 +90,6 @@ public HttpServerLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpSource.java
index 5c117e27555c..9c014c5f7cdf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HttpSource.java
@@ -112,7 +112,6 @@ public HttpSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotLinkedService.java
index fed4b8ed1677..8608e9da86d1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotLinkedService.java
@@ -299,7 +299,6 @@ public HubspotLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -307,6 +306,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(HubspotLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotObjectDataset.java
index 6e413510cde3..0461e38b95de 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public HubspotObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model HubspotObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(HubspotObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotSource.java
index 1c9f7de2c6c2..425bf4768bdc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/HubspotSource.java
@@ -126,7 +126,6 @@ public HubspotSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergDataset.java
new file mode 100644
index 000000000000..90929ee9f96a
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergDataset.java
@@ -0,0 +1,251 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.models;
+
+import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import com.azure.resourcemanager.datafactory.fluent.models.IcebergDatasetTypeProperties;
+import java.io.IOException;
+import java.util.LinkedHashMap;
+import java.util.List;
+import java.util.Map;
+
+/**
+ * Iceberg dataset.
+ */
+@Fluent
+public final class IcebergDataset extends Dataset {
+ /*
+ * Type of dataset.
+ */
+ private String type = "Iceberg";
+
+ /*
+ * Iceberg dataset properties.
+ */
+ private IcebergDatasetTypeProperties innerTypeProperties;
+
+ /**
+ * Creates an instance of IcebergDataset class.
+ */
+ public IcebergDataset() {
+ }
+
+ /**
+ * Get the type property: Type of dataset.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Get the innerTypeProperties property: Iceberg dataset properties.
+ *
+ * @return the innerTypeProperties value.
+ */
+ private IcebergDatasetTypeProperties innerTypeProperties() {
+ return this.innerTypeProperties;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergDataset withDescription(String description) {
+ super.withDescription(description);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergDataset withStructure(Object structure) {
+ super.withStructure(structure);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergDataset withSchema(Object schema) {
+ super.withSchema(schema);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergDataset withLinkedServiceName(LinkedServiceReference linkedServiceName) {
+ super.withLinkedServiceName(linkedServiceName);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergDataset withParameters(Map parameters) {
+ super.withParameters(parameters);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergDataset withAnnotations(List annotations) {
+ super.withAnnotations(annotations);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergDataset withFolder(DatasetFolder folder) {
+ super.withFolder(folder);
+ return this;
+ }
+
+ /**
+ * Get the location property: The location of the iceberg storage. Setting a file name is not allowed for iceberg
+ * format.
+ *
+ * @return the location value.
+ */
+ public DatasetLocation location() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().location();
+ }
+
+ /**
+ * Set the location property: The location of the iceberg storage. Setting a file name is not allowed for iceberg
+ * format.
+ *
+ * @param location the location value to set.
+ * @return the IcebergDataset object itself.
+ */
+ public IcebergDataset withLocation(DatasetLocation location) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new IcebergDatasetTypeProperties();
+ }
+ this.innerTypeProperties().withLocation(location);
+ return this;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ @Override
+ public void validate() {
+ if (innerTypeProperties() != null) {
+ innerTypeProperties().validate();
+ }
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model IcebergDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
+ }
+
+ private static final ClientLogger LOGGER = new ClientLogger(IcebergDataset.class);
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeJsonField("linkedServiceName", linkedServiceName());
+ jsonWriter.writeStringField("description", description());
+ jsonWriter.writeUntypedField("structure", structure());
+ jsonWriter.writeUntypedField("schema", schema());
+ jsonWriter.writeMapField("parameters", parameters(), (writer, element) -> writer.writeJson(element));
+ jsonWriter.writeArrayField("annotations", annotations(), (writer, element) -> writer.writeUntyped(element));
+ jsonWriter.writeJsonField("folder", folder());
+ jsonWriter.writeStringField("type", this.type);
+ jsonWriter.writeJsonField("typeProperties", this.innerTypeProperties);
+ if (additionalProperties() != null) {
+ for (Map.Entry additionalProperty : additionalProperties().entrySet()) {
+ jsonWriter.writeUntypedField(additionalProperty.getKey(), additionalProperty.getValue());
+ }
+ }
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of IcebergDataset from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of IcebergDataset if the JsonReader was pointing to an instance of it, or null if it was
+ * pointing to JSON null.
+ * @throws IllegalStateException If the deserialized JSON object was missing any required properties.
+ * @throws IOException If an error occurs while reading the IcebergDataset.
+ */
+ public static IcebergDataset fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ IcebergDataset deserializedIcebergDataset = new IcebergDataset();
+ Map additionalProperties = null;
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("linkedServiceName".equals(fieldName)) {
+ deserializedIcebergDataset.withLinkedServiceName(LinkedServiceReference.fromJson(reader));
+ } else if ("description".equals(fieldName)) {
+ deserializedIcebergDataset.withDescription(reader.getString());
+ } else if ("structure".equals(fieldName)) {
+ deserializedIcebergDataset.withStructure(reader.readUntyped());
+ } else if ("schema".equals(fieldName)) {
+ deserializedIcebergDataset.withSchema(reader.readUntyped());
+ } else if ("parameters".equals(fieldName)) {
+ Map parameters
+ = reader.readMap(reader1 -> ParameterSpecification.fromJson(reader1));
+ deserializedIcebergDataset.withParameters(parameters);
+ } else if ("annotations".equals(fieldName)) {
+ List annotations = reader.readArray(reader1 -> reader1.readUntyped());
+ deserializedIcebergDataset.withAnnotations(annotations);
+ } else if ("folder".equals(fieldName)) {
+ deserializedIcebergDataset.withFolder(DatasetFolder.fromJson(reader));
+ } else if ("type".equals(fieldName)) {
+ deserializedIcebergDataset.type = reader.getString();
+ } else if ("typeProperties".equals(fieldName)) {
+ deserializedIcebergDataset.innerTypeProperties = IcebergDatasetTypeProperties.fromJson(reader);
+ } else {
+ if (additionalProperties == null) {
+ additionalProperties = new LinkedHashMap<>();
+ }
+
+ additionalProperties.put(fieldName, reader.readUntyped());
+ }
+ }
+ deserializedIcebergDataset.withAdditionalProperties(additionalProperties);
+
+ return deserializedIcebergDataset;
+ });
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergSink.java
new file mode 100644
index 000000000000..562f52535e6f
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergSink.java
@@ -0,0 +1,230 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.models;
+
+import com.azure.core.annotation.Fluent;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import java.io.IOException;
+import java.util.LinkedHashMap;
+import java.util.Map;
+
+/**
+ * A copy activity Iceberg sink.
+ */
+@Fluent
+public final class IcebergSink extends CopySink {
+ /*
+ * Copy sink type.
+ */
+ private String type = "IcebergSink";
+
+ /*
+ * Iceberg store settings.
+ */
+ private StoreWriteSettings storeSettings;
+
+ /*
+ * Iceberg format settings.
+ */
+ private IcebergWriteSettings formatSettings;
+
+ /**
+ * Creates an instance of IcebergSink class.
+ */
+ public IcebergSink() {
+ }
+
+ /**
+ * Get the type property: Copy sink type.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Get the storeSettings property: Iceberg store settings.
+ *
+ * @return the storeSettings value.
+ */
+ public StoreWriteSettings storeSettings() {
+ return this.storeSettings;
+ }
+
+ /**
+ * Set the storeSettings property: Iceberg store settings.
+ *
+ * @param storeSettings the storeSettings value to set.
+ * @return the IcebergSink object itself.
+ */
+ public IcebergSink withStoreSettings(StoreWriteSettings storeSettings) {
+ this.storeSettings = storeSettings;
+ return this;
+ }
+
+ /**
+ * Get the formatSettings property: Iceberg format settings.
+ *
+ * @return the formatSettings value.
+ */
+ public IcebergWriteSettings formatSettings() {
+ return this.formatSettings;
+ }
+
+ /**
+ * Set the formatSettings property: Iceberg format settings.
+ *
+ * @param formatSettings the formatSettings value to set.
+ * @return the IcebergSink object itself.
+ */
+ public IcebergSink withFormatSettings(IcebergWriteSettings formatSettings) {
+ this.formatSettings = formatSettings;
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergSink withWriteBatchSize(Object writeBatchSize) {
+ super.withWriteBatchSize(writeBatchSize);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergSink withWriteBatchTimeout(Object writeBatchTimeout) {
+ super.withWriteBatchTimeout(writeBatchTimeout);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergSink withSinkRetryCount(Object sinkRetryCount) {
+ super.withSinkRetryCount(sinkRetryCount);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergSink withSinkRetryWait(Object sinkRetryWait) {
+ super.withSinkRetryWait(sinkRetryWait);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergSink withMaxConcurrentConnections(Object maxConcurrentConnections) {
+ super.withMaxConcurrentConnections(maxConcurrentConnections);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public IcebergSink withDisableMetricsCollection(Object disableMetricsCollection) {
+ super.withDisableMetricsCollection(disableMetricsCollection);
+ return this;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ @Override
+ public void validate() {
+ if (storeSettings() != null) {
+ storeSettings().validate();
+ }
+ if (formatSettings() != null) {
+ formatSettings().validate();
+ }
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeUntypedField("writeBatchSize", writeBatchSize());
+ jsonWriter.writeUntypedField("writeBatchTimeout", writeBatchTimeout());
+ jsonWriter.writeUntypedField("sinkRetryCount", sinkRetryCount());
+ jsonWriter.writeUntypedField("sinkRetryWait", sinkRetryWait());
+ jsonWriter.writeUntypedField("maxConcurrentConnections", maxConcurrentConnections());
+ jsonWriter.writeUntypedField("disableMetricsCollection", disableMetricsCollection());
+ jsonWriter.writeStringField("type", this.type);
+ jsonWriter.writeJsonField("storeSettings", this.storeSettings);
+ jsonWriter.writeJsonField("formatSettings", this.formatSettings);
+ if (additionalProperties() != null) {
+ for (Map.Entry additionalProperty : additionalProperties().entrySet()) {
+ jsonWriter.writeUntypedField(additionalProperty.getKey(), additionalProperty.getValue());
+ }
+ }
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of IcebergSink from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of IcebergSink if the JsonReader was pointing to an instance of it, or null if it was
+ * pointing to JSON null.
+ * @throws IOException If an error occurs while reading the IcebergSink.
+ */
+ public static IcebergSink fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ IcebergSink deserializedIcebergSink = new IcebergSink();
+ Map additionalProperties = null;
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("writeBatchSize".equals(fieldName)) {
+ deserializedIcebergSink.withWriteBatchSize(reader.readUntyped());
+ } else if ("writeBatchTimeout".equals(fieldName)) {
+ deserializedIcebergSink.withWriteBatchTimeout(reader.readUntyped());
+ } else if ("sinkRetryCount".equals(fieldName)) {
+ deserializedIcebergSink.withSinkRetryCount(reader.readUntyped());
+ } else if ("sinkRetryWait".equals(fieldName)) {
+ deserializedIcebergSink.withSinkRetryWait(reader.readUntyped());
+ } else if ("maxConcurrentConnections".equals(fieldName)) {
+ deserializedIcebergSink.withMaxConcurrentConnections(reader.readUntyped());
+ } else if ("disableMetricsCollection".equals(fieldName)) {
+ deserializedIcebergSink.withDisableMetricsCollection(reader.readUntyped());
+ } else if ("type".equals(fieldName)) {
+ deserializedIcebergSink.type = reader.getString();
+ } else if ("storeSettings".equals(fieldName)) {
+ deserializedIcebergSink.storeSettings = StoreWriteSettings.fromJson(reader);
+ } else if ("formatSettings".equals(fieldName)) {
+ deserializedIcebergSink.formatSettings = IcebergWriteSettings.fromJson(reader);
+ } else {
+ if (additionalProperties == null) {
+ additionalProperties = new LinkedHashMap<>();
+ }
+
+ additionalProperties.put(fieldName, reader.readUntyped());
+ }
+ }
+ deserializedIcebergSink.withAdditionalProperties(additionalProperties);
+
+ return deserializedIcebergSink;
+ });
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergWriteSettings.java
new file mode 100644
index 000000000000..02c1527f4ae3
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IcebergWriteSettings.java
@@ -0,0 +1,96 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.models;
+
+import com.azure.core.annotation.Immutable;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import java.io.IOException;
+import java.util.LinkedHashMap;
+import java.util.Map;
+
+/**
+ * Iceberg write settings.
+ */
+@Immutable
+public final class IcebergWriteSettings extends FormatWriteSettings {
+ /*
+ * The write setting type.
+ */
+ private String type = "IcebergWriteSettings";
+
+ /**
+ * Creates an instance of IcebergWriteSettings class.
+ */
+ public IcebergWriteSettings() {
+ }
+
+ /**
+ * Get the type property: The write setting type.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ @Override
+ public void validate() {
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeStringField("type", this.type);
+ if (additionalProperties() != null) {
+ for (Map.Entry additionalProperty : additionalProperties().entrySet()) {
+ jsonWriter.writeUntypedField(additionalProperty.getKey(), additionalProperty.getValue());
+ }
+ }
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of IcebergWriteSettings from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of IcebergWriteSettings if the JsonReader was pointing to an instance of it, or null if it
+ * was pointing to JSON null.
+ * @throws IOException If an error occurs while reading the IcebergWriteSettings.
+ */
+ public static IcebergWriteSettings fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ IcebergWriteSettings deserializedIcebergWriteSettings = new IcebergWriteSettings();
+ Map additionalProperties = null;
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("type".equals(fieldName)) {
+ deserializedIcebergWriteSettings.type = reader.getString();
+ } else {
+ if (additionalProperties == null) {
+ additionalProperties = new LinkedHashMap<>();
+ }
+
+ additionalProperties.put(fieldName, reader.readUntyped());
+ }
+ }
+ deserializedIcebergWriteSettings.withAdditionalProperties(additionalProperties);
+
+ return deserializedIcebergWriteSettings;
+ });
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IfConditionActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IfConditionActivity.java
index b0e5e04caf66..0e01f6815d24 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IfConditionActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IfConditionActivity.java
@@ -192,7 +192,6 @@ public IfConditionActivity withIfFalseActivities(List ifFalseActivitie
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -200,6 +199,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model IfConditionActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(IfConditionActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaLinkedService.java
index 9ab56ea5ca32..773c5600910d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaLinkedService.java
@@ -378,7 +378,6 @@ public ImpalaLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -386,6 +385,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ImpalaLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaObjectDataset.java
index 7989b5301694..139bc4b7b616 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public ImpalaObjectDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ImpalaObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ImpalaObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaSource.java
index 0ce680624558..b8bee898a8aa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ImpalaSource.java
@@ -126,7 +126,6 @@ public ImpalaSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixLinkedService.java
index a1e37e26af88..283db8934c24 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixLinkedService.java
@@ -257,7 +257,6 @@ public InformixLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -265,6 +264,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(InformixLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSink.java
index 04711eb31826..c23778a6717c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSink.java
@@ -126,7 +126,6 @@ public InformixSink withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSource.java
index 45c471071124..cc45b7ff0689 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixSource.java
@@ -124,7 +124,6 @@ public InformixSource withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixTableDataset.java
index 94bd03d353dd..aaa3f7b30eb0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/InformixTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public InformixTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model InformixTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(InformixTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeDebugResource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeDebugResource.java
index 407f81e60f8d..2d2233053f49 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeDebugResource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeDebugResource.java
@@ -63,7 +63,6 @@ public IntegrationRuntimeDebugResource withName(String name) {
*/
@Override
public void validate() {
- super.validate();
if (properties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeReference.java
index f848809bce07..a04f3352b044 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/IntegrationRuntimeReference.java
@@ -21,7 +21,7 @@ public final class IntegrationRuntimeReference implements JsonSerializable {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(JiraLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraObjectDataset.java
index 7c1ff0919258..68e006091e06 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public JiraObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model JiraObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(JiraObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraSource.java
index 7d2fbcb6fce1..a7fd74d96d31 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JiraSource.java
@@ -126,7 +126,6 @@ public JiraSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonDataset.java
index 175df8b75bfe..5a57ab2e97c0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,29 @@ public JsonDataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property linkedServiceName in model JsonDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(JsonDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonFormat.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonFormat.java
index c45705f27dd2..0142097b3614 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonFormat.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonFormat.java
@@ -215,7 +215,6 @@ public JsonFormat withDeserializer(Object deserializer) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonReadSettings.java
index b8c42ca582d9..24af16db413e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonReadSettings.java
@@ -70,7 +70,6 @@ public JsonReadSettings withCompressionProperties(CompressionReadSettings compre
*/
@Override
public void validate() {
- super.validate();
if (compressionProperties() != null) {
compressionProperties().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSink.java
index eac691067ead..bcc40c274dcc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSink.java
@@ -149,7 +149,6 @@ public JsonSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSource.java
index d3422261de45..e3f47b4552f1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonSource.java
@@ -159,7 +159,6 @@ public JsonSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonWriteSettings.java
index 8e1aaad013ee..7ae47cfbeadb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/JsonWriteSettings.java
@@ -73,7 +73,6 @@ public JsonWriteSettings withFilePattern(Object filePattern) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLinkedService.java
index 0980587865c3..d7dc282d7af2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLinkedService.java
@@ -313,7 +313,6 @@ public LakeHouseLinkedService withServicePrincipalCredential(SecretBase serviceP
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -321,6 +320,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(LakeHouseLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLocation.java
index 3ef5258d793c..8da6ea000ffa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseLocation.java
@@ -63,7 +63,6 @@ public LakeHouseLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseReadSettings.java
index abb338258e4b..96f5d16bdf79 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseReadSettings.java
@@ -309,7 +309,6 @@ public LakeHouseReadSettings withDisableMetricsCollection(Object disableMetricsC
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableDataset.java
index 4f27925ca5df..f3abf30d9f4b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -174,12 +175,30 @@ public LakeHouseTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model LakeHouseTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(LakeHouseTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSink.java
index 4668c41f53a8..389b908fc283 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSink.java
@@ -182,7 +182,6 @@ public LakeHouseTableSink withDisableMetricsCollection(Object disableMetricsColl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSource.java
index 21dd10bfbb74..077848b0ff49 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseTableSource.java
@@ -163,7 +163,6 @@ public LakeHouseTableSource withDisableMetricsCollection(Object disableMetricsCo
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseWriteSettings.java
index d9a7c4ca81f8..180cb0d6e59a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LakeHouseWriteSettings.java
@@ -82,7 +82,9 @@ public LakeHouseWriteSettings withMetadata(List metadata) {
*/
@Override
public void validate() {
- super.validate();
+ if (metadata() != null) {
+ metadata().forEach(e -> e.validate());
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeKeyAuthorization.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeKeyAuthorization.java
index bfb5253ed94e..5f3a49984e2c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeKeyAuthorization.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeKeyAuthorization.java
@@ -69,7 +69,6 @@ public LinkedIntegrationRuntimeKeyAuthorization withKey(SecureString key) {
*/
@Override
public void validate() {
- super.validate();
if (key() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeRbacAuthorization.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeRbacAuthorization.java
index a2ae750c7dc7..7fd975f4cbfe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeRbacAuthorization.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedIntegrationRuntimeRbacAuthorization.java
@@ -94,7 +94,6 @@ public LinkedIntegrationRuntimeRbacAuthorization withCredential(CredentialRefere
*/
@Override
public void validate() {
- super.validate();
if (resourceId() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceDebugResource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceDebugResource.java
index 9a7249201850..3ec2ce151679 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceDebugResource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceDebugResource.java
@@ -63,7 +63,6 @@ public LinkedServiceDebugResource withName(String name) {
*/
@Override
public void validate() {
- super.validate();
if (properties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceReference.java
index 7c74e311c43d..02853b4660aa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/LinkedServiceReference.java
@@ -21,7 +21,7 @@ public final class LinkedServiceReference implements JsonSerializable e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(LookupActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoLinkedService.java
index 6afddec9aec1..e70549c39ee4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoLinkedService.java
@@ -253,7 +253,6 @@ public MagentoLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -261,6 +260,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MagentoLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoObjectDataset.java
index 06753e563b5d..d3268529c352 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public MagentoObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MagentoObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(MagentoObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoSource.java
index 44f7a5a12401..d20ca35da216 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MagentoSource.java
@@ -126,7 +126,6 @@ public MagentoSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIdentityCredential.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIdentityCredential.java
index 0c7f17959e46..4b46fc7c0c5c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIdentityCredential.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIdentityCredential.java
@@ -102,7 +102,6 @@ public ManagedIdentityCredential withResourceId(String resourceId) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntime.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntime.java
index b3e5ee15711b..643a57202517 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntime.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntime.java
@@ -181,7 +181,6 @@ public IntegrationRuntimeCustomerVirtualNetwork customerVirtualNetwork() {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntimeStatus.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntimeStatus.java
index 2369f563c738..7344ce9fe94f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntimeStatus.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ManagedIntegrationRuntimeStatus.java
@@ -32,16 +32,6 @@ public final class ManagedIntegrationRuntimeStatus extends IntegrationRuntimeSta
private ManagedIntegrationRuntimeStatusTypeProperties innerTypeProperties
= new ManagedIntegrationRuntimeStatusTypeProperties();
- /*
- * The data factory name which the integration runtime belong to.
- */
- private String dataFactoryName;
-
- /*
- * The state of integration runtime.
- */
- private IntegrationRuntimeState state;
-
/**
* Creates an instance of ManagedIntegrationRuntimeStatus class.
*/
@@ -67,26 +57,6 @@ private ManagedIntegrationRuntimeStatusTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the dataFactoryName property: The data factory name which the integration runtime belong to.
- *
- * @return the dataFactoryName value.
- */
- @Override
- public String dataFactoryName() {
- return this.dataFactoryName;
- }
-
- /**
- * Get the state property: The state of integration runtime.
- *
- * @return the state value.
- */
- @Override
- public IntegrationRuntimeState state() {
- return this.state;
- }
-
/**
* Get the createTime property: The time at which the integration runtime was created, in ISO8601 format.
*
@@ -130,7 +100,6 @@ public ManagedIntegrationRuntimeOperationResult lastOperation() {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -177,10 +146,10 @@ public static ManagedIntegrationRuntimeStatus fromJson(JsonReader jsonReader) th
reader.nextToken();
if ("dataFactoryName".equals(fieldName)) {
- deserializedManagedIntegrationRuntimeStatus.dataFactoryName = reader.getString();
+ deserializedManagedIntegrationRuntimeStatus.withDataFactoryName(reader.getString());
} else if ("state".equals(fieldName)) {
- deserializedManagedIntegrationRuntimeStatus.state
- = IntegrationRuntimeState.fromString(reader.getString());
+ deserializedManagedIntegrationRuntimeStatus
+ .withState(IntegrationRuntimeState.fromString(reader.getString()));
} else if ("typeProperties".equals(fieldName)) {
deserializedManagedIntegrationRuntimeStatus.innerTypeProperties
= ManagedIntegrationRuntimeStatusTypeProperties.fromJson(reader);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MappingDataFlow.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MappingDataFlow.java
index 7e7bb640877f..aed09f0866fd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MappingDataFlow.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MappingDataFlow.java
@@ -201,10 +201,12 @@ public MappingDataFlow withScriptLines(List scriptLines) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (folder() != null) {
+ folder().validate();
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBLinkedService.java
index 31049e886fd2..01ebfb7b1420 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBLinkedService.java
@@ -102,7 +102,8 @@ public MariaDBLinkedService withAnnotations(List annotations) {
/**
* Get the driverVersion property: The version of the MariaDB driver. Type: string. V1 or empty for legacy driver,
- * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string.
+ * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string. The
+ * legacy driver is scheduled for deprecation by October 2024.
*
* @return the driverVersion value.
*/
@@ -112,7 +113,8 @@ public Object driverVersion() {
/**
* Set the driverVersion property: The version of the MariaDB driver. Type: string. V1 or empty for legacy driver,
- * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string.
+ * V2 for new driver. V1 can support connection string and property bag, V2 can only support connection string. The
+ * legacy driver is scheduled for deprecation by October 2024.
*
* @param driverVersion the driverVersion value to set.
* @return the MariaDBLinkedService object itself.
@@ -242,6 +244,62 @@ public MariaDBLinkedService withDatabase(Object database) {
return this;
}
+ /**
+ * Get the sslMode property: This option specifies whether the driver uses TLS encryption and verification when
+ * connecting to MariaDB. E.g., SSLMode=<0/1/2/3/4>. Options: DISABLED (0) / PREFERRED (1) (Default) /
+ * REQUIRED (2) / VERIFY_CA (3) / VERIFY_IDENTITY (4), REQUIRED (2) is recommended to only allow connections
+ * encrypted with SSL/TLS.
+ *
+ * @return the sslMode value.
+ */
+ public Object sslMode() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().sslMode();
+ }
+
+ /**
+ * Set the sslMode property: This option specifies whether the driver uses TLS encryption and verification when
+ * connecting to MariaDB. E.g., SSLMode=<0/1/2/3/4>. Options: DISABLED (0) / PREFERRED (1) (Default) /
+ * REQUIRED (2) / VERIFY_CA (3) / VERIFY_IDENTITY (4), REQUIRED (2) is recommended to only allow connections
+ * encrypted with SSL/TLS.
+ *
+ * @param sslMode the sslMode value to set.
+ * @return the MariaDBLinkedService object itself.
+ */
+ public MariaDBLinkedService withSslMode(Object sslMode) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MariaDBLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withSslMode(sslMode);
+ return this;
+ }
+
+ /**
+ * Get the useSystemTrustStore property: This option specifies whether to use a CA certificate from the system trust
+ * store, or from a specified PEM file. E.g. UseSystemTrustStore=<0/1>; Options: Enabled (1) / Disabled (0)
+ * (Default).
+ *
+ * @return the useSystemTrustStore value.
+ */
+ public Object useSystemTrustStore() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().useSystemTrustStore();
+ }
+
+ /**
+ * Set the useSystemTrustStore property: This option specifies whether to use a CA certificate from the system trust
+ * store, or from a specified PEM file. E.g. UseSystemTrustStore=<0/1>; Options: Enabled (1) / Disabled (0)
+ * (Default).
+ *
+ * @param useSystemTrustStore the useSystemTrustStore value to set.
+ * @return the MariaDBLinkedService object itself.
+ */
+ public MariaDBLinkedService withUseSystemTrustStore(Object useSystemTrustStore) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MariaDBLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withUseSystemTrustStore(useSystemTrustStore);
+ return this;
+ }
+
/**
* Get the password property: The Azure key vault secret reference of password in connection string.
*
@@ -297,7 +355,6 @@ public MariaDBLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -305,6 +362,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MariaDBLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBSource.java
index 84e499d9497e..8ddb92b1cf3c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBSource.java
@@ -126,7 +126,6 @@ public MariaDBSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBTableDataset.java
index 0f81027ff50d..6106db18d141 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MariaDBTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public MariaDBTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MariaDBTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(MariaDBTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoLinkedService.java
index b65a2df18285..8454840f6c25 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoLinkedService.java
@@ -276,7 +276,6 @@ public MarketoLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -284,6 +283,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MarketoLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoObjectDataset.java
index ddfd184d69f7..6b18977de376 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public MarketoObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MarketoObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(MarketoObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoSource.java
index 0cd2893b3f31..84ebc7114ef2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MarketoSource.java
@@ -126,7 +126,6 @@ public MarketoSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessLinkedService.java
index 3cc4d4c6bc61..f6c41e035517 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessLinkedService.java
@@ -258,7 +258,6 @@ public MicrosoftAccessLinkedService withEncryptedCredential(String encryptedCred
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -266,6 +265,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MicrosoftAccessLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSink.java
index 7267820fff09..58b262970ab7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSink.java
@@ -126,7 +126,6 @@ public MicrosoftAccessSink withDisableMetricsCollection(Object disableMetricsCol
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSource.java
index 032f2c145358..af7f9dc8c1ad 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessSource.java
@@ -134,7 +134,6 @@ public MicrosoftAccessSource withDisableMetricsCollection(Object disableMetricsC
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessTableDataset.java
index 7827ebec03de..4e5ff8726b96 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MicrosoftAccessTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public MicrosoftAccessTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MicrosoftAccessTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(MicrosoftAccessTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasCollectionDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasCollectionDataset.java
index 1a4bc0e80c14..96c6c64c2ec9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasCollectionDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasCollectionDataset.java
@@ -151,7 +151,6 @@ public MongoDbAtlasCollectionDataset withCollection(Object collection) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -159,6 +158,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MongoDbAtlasCollectionDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MongoDbAtlasCollectionDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasLinkedService.java
index 82207b7f9093..cbe6237ce624 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasLinkedService.java
@@ -182,7 +182,6 @@ public MongoDbAtlasLinkedService withDriverVersion(Object driverVersion) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -190,6 +189,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MongoDbAtlasLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSink.java
index 92831188e337..4cd9dc162349 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSink.java
@@ -130,7 +130,6 @@ public MongoDbAtlasSink withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSource.java
index 3155546c2e54..504a8f5d7a86 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbAtlasSource.java
@@ -225,7 +225,6 @@ public MongoDbAtlasSource withDisableMetricsCollection(Object disableMetricsColl
*/
@Override
public void validate() {
- super.validate();
if (cursorMethods() != null) {
cursorMethods().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbCollectionDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbCollectionDataset.java
index 4d6a0f90edeb..f6b12a727cff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbCollectionDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbCollectionDataset.java
@@ -150,7 +150,6 @@ public MongoDbCollectionDataset withCollectionName(Object collectionName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -158,6 +157,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MongoDbCollectionDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MongoDbCollectionDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbLinkedService.java
index f3f7f09a1263..f54628f44372 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbLinkedService.java
@@ -351,7 +351,6 @@ public MongoDbLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -359,6 +358,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MongoDbLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbSource.java
index 195646656083..1dfe2f883d83 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbSource.java
@@ -136,7 +136,6 @@ public MongoDbSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2CollectionDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2CollectionDataset.java
index 2f8fcd0feb7e..1c3441804168 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2CollectionDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2CollectionDataset.java
@@ -151,7 +151,6 @@ public MongoDbV2CollectionDataset withCollection(Object collection) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -159,6 +158,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MongoDbV2CollectionDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MongoDbV2CollectionDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2LinkedService.java
index 89ac1f770ef4..e3c48df90ba0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2LinkedService.java
@@ -157,7 +157,6 @@ public MongoDbV2LinkedService withDatabase(Object database) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -165,6 +164,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MongoDbV2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Sink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Sink.java
index a5fae7f2a54c..a1c50d5b6baf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Sink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Sink.java
@@ -130,7 +130,6 @@ public MongoDbV2Sink withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Source.java
index 9799a1ffa237..41c998e0a59f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MongoDbV2Source.java
@@ -225,7 +225,6 @@ public MongoDbV2Source withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
if (cursorMethods() != null) {
cursorMethods().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MultiplePipelineTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MultiplePipelineTrigger.java
index 509fce7263c6..e35281808a44 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MultiplePipelineTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MultiplePipelineTrigger.java
@@ -28,11 +28,6 @@ public class MultiplePipelineTrigger extends Trigger {
*/
private List pipelines;
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of MultiplePipelineTrigger class.
*/
@@ -69,17 +64,6 @@ public MultiplePipelineTrigger withPipelines(List pipe
return this;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -105,7 +89,6 @@ public MultiplePipelineTrigger withAnnotations(List annotations) {
*/
@Override
public void validate() {
- super.validate();
if (pipelines() != null) {
pipelines().forEach(e -> e.validate());
}
@@ -179,8 +162,8 @@ static MultiplePipelineTrigger fromJsonKnownDiscriminator(JsonReader jsonReader)
if ("description".equals(fieldName)) {
deserializedMultiplePipelineTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedMultiplePipelineTrigger.runtimeState
- = TriggerRuntimeState.fromString(reader.getString());
+ deserializedMultiplePipelineTrigger
+ .withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedMultiplePipelineTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlLinkedService.java
index 20d67dbeee19..eaf78ec21da3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlLinkedService.java
@@ -340,6 +340,181 @@ public MySqlLinkedService withEncryptedCredential(String encryptedCredential) {
return this;
}
+ /**
+ * Get the allowZeroDateTime property: This allows the special “zero” date value 0000-00-00 to be retrieved from the
+ * database. Type: boolean.
+ *
+ * @return the allowZeroDateTime value.
+ */
+ public Object allowZeroDateTime() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().allowZeroDateTime();
+ }
+
+ /**
+ * Set the allowZeroDateTime property: This allows the special “zero” date value 0000-00-00 to be retrieved from the
+ * database. Type: boolean.
+ *
+ * @param allowZeroDateTime the allowZeroDateTime value to set.
+ * @return the MySqlLinkedService object itself.
+ */
+ public MySqlLinkedService withAllowZeroDateTime(Object allowZeroDateTime) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MySqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withAllowZeroDateTime(allowZeroDateTime);
+ return this;
+ }
+
+ /**
+ * Get the connectionTimeout property: The length of time (in seconds) to wait for a connection to the server before
+ * terminating the attempt and generating an error. Type: integer.
+ *
+ * @return the connectionTimeout value.
+ */
+ public Object connectionTimeout() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().connectionTimeout();
+ }
+
+ /**
+ * Set the connectionTimeout property: The length of time (in seconds) to wait for a connection to the server before
+ * terminating the attempt and generating an error. Type: integer.
+ *
+ * @param connectionTimeout the connectionTimeout value to set.
+ * @return the MySqlLinkedService object itself.
+ */
+ public MySqlLinkedService withConnectionTimeout(Object connectionTimeout) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MySqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withConnectionTimeout(connectionTimeout);
+ return this;
+ }
+
+ /**
+ * Get the convertZeroDateTime property: True to return DateTime.MinValue for date or datetime columns that have
+ * disallowed values. Type: boolean.
+ *
+ * @return the convertZeroDateTime value.
+ */
+ public Object convertZeroDateTime() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().convertZeroDateTime();
+ }
+
+ /**
+ * Set the convertZeroDateTime property: True to return DateTime.MinValue for date or datetime columns that have
+ * disallowed values. Type: boolean.
+ *
+ * @param convertZeroDateTime the convertZeroDateTime value to set.
+ * @return the MySqlLinkedService object itself.
+ */
+ public MySqlLinkedService withConvertZeroDateTime(Object convertZeroDateTime) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MySqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withConvertZeroDateTime(convertZeroDateTime);
+ return this;
+ }
+
+ /**
+ * Get the guidFormat property: Determines which column type (if any) should be read as a GUID. Type: string. None:
+ * No column types are automatically read as a Guid; Char36: All CHAR(36) columns are read/written as a Guid using
+ * lowercase hex with hyphens, which matches UUID.
+ *
+ * @return the guidFormat value.
+ */
+ public Object guidFormat() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().guidFormat();
+ }
+
+ /**
+ * Set the guidFormat property: Determines which column type (if any) should be read as a GUID. Type: string. None:
+ * No column types are automatically read as a Guid; Char36: All CHAR(36) columns are read/written as a Guid using
+ * lowercase hex with hyphens, which matches UUID.
+ *
+ * @param guidFormat the guidFormat value to set.
+ * @return the MySqlLinkedService object itself.
+ */
+ public MySqlLinkedService withGuidFormat(Object guidFormat) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MySqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withGuidFormat(guidFormat);
+ return this;
+ }
+
+ /**
+ * Get the sslCert property: The path to the client’s SSL certificate file in PEM format. SslKey must also be
+ * specified. Type: string.
+ *
+ * @return the sslCert value.
+ */
+ public Object sslCert() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().sslCert();
+ }
+
+ /**
+ * Set the sslCert property: The path to the client’s SSL certificate file in PEM format. SslKey must also be
+ * specified. Type: string.
+ *
+ * @param sslCert the sslCert value to set.
+ * @return the MySqlLinkedService object itself.
+ */
+ public MySqlLinkedService withSslCert(Object sslCert) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MySqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withSslCert(sslCert);
+ return this;
+ }
+
+ /**
+ * Get the sslKey property: The path to the client’s SSL private key in PEM format. SslCert must also be specified.
+ * Type: string.
+ *
+ * @return the sslKey value.
+ */
+ public Object sslKey() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().sslKey();
+ }
+
+ /**
+ * Set the sslKey property: The path to the client’s SSL private key in PEM format. SslCert must also be specified.
+ * Type: string.
+ *
+ * @param sslKey the sslKey value to set.
+ * @return the MySqlLinkedService object itself.
+ */
+ public MySqlLinkedService withSslKey(Object sslKey) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MySqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withSslKey(sslKey);
+ return this;
+ }
+
+ /**
+ * Get the treatTinyAsBoolean property: When set to true, TINYINT(1) values are returned as booleans. Type: bool.
+ *
+ * @return the treatTinyAsBoolean value.
+ */
+ public Object treatTinyAsBoolean() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().treatTinyAsBoolean();
+ }
+
+ /**
+ * Set the treatTinyAsBoolean property: When set to true, TINYINT(1) values are returned as booleans. Type: bool.
+ *
+ * @param treatTinyAsBoolean the treatTinyAsBoolean value to set.
+ * @return the MySqlLinkedService object itself.
+ */
+ public MySqlLinkedService withTreatTinyAsBoolean(Object treatTinyAsBoolean) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new MySqlLinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withTreatTinyAsBoolean(treatTinyAsBoolean);
+ return this;
+ }
+
/**
* Validates the instance.
*
@@ -347,7 +522,6 @@ public MySqlLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -355,6 +529,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(MySqlLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlSource.java
index f93d0564957d..2e6c038169c8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlSource.java
@@ -124,7 +124,6 @@ public MySqlSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlTableDataset.java
index 01f749543ffe..b3e4e9cb04dd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/MySqlTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public MySqlTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model MySqlTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(MySqlTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaLinkedService.java
index 7311ac57358f..cb243bd6daf4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaLinkedService.java
@@ -180,7 +180,6 @@ public NetezzaLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(NetezzaLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaSource.java
index 21000ebc81ee..26e0284e8f3b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaSource.java
@@ -179,7 +179,6 @@ public NetezzaSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaTableDataset.java
index 02d0d62102a9..5254fe84fcd0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/NetezzaTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public NetezzaTableDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model NetezzaTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(NetezzaTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataLinkedService.java
index 96324e8687a1..d0b10525b70f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataLinkedService.java
@@ -459,7 +459,6 @@ public ODataLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -467,6 +466,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ODataLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataResourceDataset.java
index 286e750113ce..a90706208955 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataResourceDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public ODataResourceDataset withPath(Object path) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ODataResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ODataResourceDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataSource.java
index 7ca71c826d91..b9392c2ddc2f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ODataSource.java
@@ -165,7 +165,6 @@ public ODataSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcLinkedService.java
index 2c8ddeadc58c..40669bad6b0a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcLinkedService.java
@@ -257,7 +257,6 @@ public OdbcLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -265,6 +264,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(OdbcLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSink.java
index 5d5cc06ce460..d77b4c17fb00 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSink.java
@@ -126,7 +126,6 @@ public OdbcSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSource.java
index 6e1b24b4cc2f..6137cc23f377 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcSource.java
@@ -124,7 +124,6 @@ public OdbcSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcTableDataset.java
index 7d33932fafe0..c0ac7a58612d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OdbcTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public OdbcTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model OdbcTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(OdbcTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Dataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Dataset.java
index 5b3747e8f0d2..b4be3b1c44bf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Dataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Dataset.java
@@ -175,7 +175,6 @@ public Office365Dataset withPredicate(Object predicate) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -183,6 +182,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model Office365Dataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(Office365Dataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365LinkedService.java
index d01bb6218b53..a4b444260a9c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365LinkedService.java
@@ -230,7 +230,6 @@ public Office365LinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -238,6 +237,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(Office365LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Source.java
index bad9030874a7..eea156905401 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/Office365Source.java
@@ -245,7 +245,6 @@ public Office365Source withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLinkedService.java
index 37e550a9d95e..cd665322090b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLinkedService.java
@@ -210,7 +210,6 @@ public OracleCloudStorageLinkedService withEncryptedCredential(String encryptedC
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -218,6 +217,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(OracleCloudStorageLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLocation.java
index 7e87466299a9..e323514dc0a9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageLocation.java
@@ -117,7 +117,6 @@ public OracleCloudStorageLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageReadSettings.java
index 5352ce7418aa..0d975d04f82a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleCloudStorageReadSettings.java
@@ -336,7 +336,6 @@ public OracleCloudStorageReadSettings withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleLinkedService.java
index 9a68338267e1..42e724f15c68 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleLinkedService.java
@@ -180,7 +180,6 @@ public OracleLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -188,6 +187,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(OracleLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudLinkedService.java
index df2ace861c81..fa6ed075e2d2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudLinkedService.java
@@ -279,7 +279,6 @@ public OracleServiceCloudLinkedService withEncryptedCredential(String encryptedC
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -287,6 +286,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(OracleServiceCloudLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudObjectDataset.java
index b372a3672f03..0a999e3a9c5d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public OracleServiceCloudObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model OracleServiceCloudObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(OracleServiceCloudObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudSource.java
index e55171a7bf90..0196a921fb6d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleServiceCloudSource.java
@@ -126,7 +126,6 @@ public OracleServiceCloudSource withDisableMetricsCollection(Object disableMetri
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSink.java
index e364ee78a580..3a35cedb4f01 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSink.java
@@ -124,7 +124,6 @@ public OracleSink withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSource.java
index ad0f1d460a84..182511b6bcf6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleSource.java
@@ -215,7 +215,6 @@ public OracleSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleTableDataset.java
index dc367659fe45..66a8251a48ec 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OracleTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,30 @@ public OracleTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model OracleTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(OracleTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcDataset.java
index 42f422adc1af..d2327f639cae 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -172,12 +173,29 @@ public OrcDataset withOrcCompressionCodec(Object orcCompressionCodec) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property linkedServiceName in model OrcDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(OrcDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcFormat.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcFormat.java
index e1e1b7d07a23..f37c664f94c6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcFormat.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcFormat.java
@@ -63,7 +63,6 @@ public OrcFormat withDeserializer(Object deserializer) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSink.java
index 89ec929ad375..8c5d8e795d06 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSink.java
@@ -149,7 +149,6 @@ public OrcSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSource.java
index 39d1828622ee..b99c3ecc55d5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcSource.java
@@ -134,7 +134,6 @@ public OrcSource withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcWriteSettings.java
index c00e69fc5638..51f98a67b1a0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/OrcWriteSettings.java
@@ -103,7 +103,6 @@ public OrcWriteSettings withFileNamePrefix(Object fileNamePrefix) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetDataset.java
index 51ccc341215a..e04d52096a74 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -172,12 +173,30 @@ public ParquetDataset withCompressionCodec(Object compressionCodec) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ParquetDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ParquetDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetFormat.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetFormat.java
index 42753a035cf8..7ae99ec13ef9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetFormat.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetFormat.java
@@ -63,7 +63,6 @@ public ParquetFormat withDeserializer(Object deserializer) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetReadSettings.java
index bcc5f5d151d2..6dbaca18e09b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetReadSettings.java
@@ -70,7 +70,6 @@ public ParquetReadSettings withCompressionProperties(CompressionReadSettings com
*/
@Override
public void validate() {
- super.validate();
if (compressionProperties() != null) {
compressionProperties().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSink.java
index a18ae8317f1e..d091f7438478 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSink.java
@@ -149,7 +149,6 @@ public ParquetSink withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSource.java
index 4c40eadb8804..8875f1ec17b8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetSource.java
@@ -159,7 +159,6 @@ public ParquetSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetWriteSettings.java
index c838ea6b43ce..c2e7b6b75743 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ParquetWriteSettings.java
@@ -103,7 +103,6 @@ public ParquetWriteSettings withFileNamePrefix(Object fileNamePrefix) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalLinkedService.java
index 3e2a3cffc4cc..6c6f78250c72 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalLinkedService.java
@@ -276,7 +276,6 @@ public PaypalLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -284,6 +283,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(PaypalLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalObjectDataset.java
index ad42a0ff31f1..c9e540a39a7c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public PaypalObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model PaypalObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(PaypalObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalSource.java
index c4777202dc9e..3b728d625fd6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PaypalSource.java
@@ -126,7 +126,6 @@ public PaypalSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixLinkedService.java
index 1db201cbbaa8..ccaa96108e61 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixLinkedService.java
@@ -401,7 +401,6 @@ public PhoenixLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -409,6 +408,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(PhoenixLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixObjectDataset.java
index 6320b48d3e3a..a181084535f1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public PhoenixObjectDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model PhoenixObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(PhoenixObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixSource.java
index 6ac59c8cb3f3..01af2347cab1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PhoenixSource.java
@@ -126,7 +126,6 @@ public PhoenixSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PipelineReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PipelineReference.java
index cd30f02952b6..f08d974d5bd6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PipelineReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PipelineReference.java
@@ -20,7 +20,7 @@ public final class PipelineReference implements JsonSerializable {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(PostgreSqlLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlSource.java
index 2f97579788f9..4e6256cc7ef3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlSource.java
@@ -124,7 +124,6 @@ public PostgreSqlSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlTableDataset.java
index e74fae207b98..a50889c5ad8b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public PostgreSqlTableDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model PostgreSqlTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(PostgreSqlTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2LinkedService.java
index 9e28e789e1a9..da106f49bdb6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2LinkedService.java
@@ -192,6 +192,29 @@ public PostgreSqlV2LinkedService withDatabase(Object database) {
return this;
}
+ /**
+ * Get the authenticationType property: The authentication type to use. Type: string.
+ *
+ * @return the authenticationType value.
+ */
+ public Object authenticationType() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().authenticationType();
+ }
+
+ /**
+ * Set the authenticationType property: The authentication type to use. Type: string.
+ *
+ * @param authenticationType the authenticationType value to set.
+ * @return the PostgreSqlV2LinkedService object itself.
+ */
+ public PostgreSqlV2LinkedService withAuthenticationType(Object authenticationType) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new PostgreSqlV2LinkedServiceTypeProperties();
+ }
+ this.innerTypeProperties().withAuthenticationType(authenticationType);
+ return this;
+ }
+
/**
* Get the sslMode property: SSL mode for connection. Type: integer. 0: disable, 1:allow, 2: prefer, 3: require, 4:
* verify-ca, 5: verify-full. Type: integer.
@@ -562,7 +585,6 @@ public PostgreSqlV2LinkedService withEncryptedCredential(String encryptedCredent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -570,6 +592,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(PostgreSqlV2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2Source.java
index eb219fec3f41..4a3cae7f627b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2Source.java
@@ -124,7 +124,6 @@ public PostgreSqlV2Source withDisableMetricsCollection(Object disableMetricsColl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2TableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2TableDataset.java
index 9ccef3e63c99..626899545347 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2TableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PostgreSqlV2TableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -170,12 +171,30 @@ public PostgreSqlV2TableDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model PostgreSqlV2TableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(PostgreSqlV2TableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySink.java
index 79aa06e78f0b..d42368a1f92b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySink.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -116,9 +117,29 @@ public PowerQuerySink withFlowlet(DataFlowReference flowlet) {
*/
@Override
public void validate() {
- super.validate();
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model PowerQuerySink"));
+ }
+ if (dataset() != null) {
+ dataset().validate();
+ }
+ if (linkedService() != null) {
+ linkedService().validate();
+ }
+ if (flowlet() != null) {
+ flowlet().validate();
+ }
+ if (schemaLinkedService() != null) {
+ schemaLinkedService().validate();
+ }
+ if (rejectedDataLinkedService() != null) {
+ rejectedDataLinkedService().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(PowerQuerySink.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySource.java
index 602a46e64923..f94a983cf3f9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PowerQuerySource.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -107,9 +108,26 @@ public PowerQuerySource withFlowlet(DataFlowReference flowlet) {
*/
@Override
public void validate() {
- super.validate();
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model PowerQuerySource"));
+ }
+ if (dataset() != null) {
+ dataset().validate();
+ }
+ if (linkedService() != null) {
+ linkedService().validate();
+ }
+ if (flowlet() != null) {
+ flowlet().validate();
+ }
+ if (schemaLinkedService() != null) {
+ schemaLinkedService().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(PowerQuerySource.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoLinkedService.java
index c71c7a64fe35..a4b1cf7a158e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoLinkedService.java
@@ -447,7 +447,6 @@ public PrestoLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -455,6 +454,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(PrestoLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoObjectDataset.java
index 8b9ca2e3dbc8..a69cbea808f8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public PrestoObjectDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model PrestoObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(PrestoObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoSource.java
index 39c60f2c2657..27cd682e58bb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/PrestoSource.java
@@ -126,7 +126,6 @@ public PrestoSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksLinkedService.java
index 275bdacb23e0..e2b554516b0d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksLinkedService.java
@@ -320,7 +320,6 @@ public QuickBooksLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -328,6 +327,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(QuickBooksLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksObjectDataset.java
index a9323b16681d..ef65cbc0cbd4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public QuickBooksObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model QuickBooksObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(QuickBooksObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksSource.java
index 803c70159b80..010fe681e09a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickBooksSource.java
@@ -126,7 +126,6 @@ public QuickBooksSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickbaseLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickbaseLinkedService.java
index 88cc1bbf863a..fc1e7ce9a9c8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickbaseLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/QuickbaseLinkedService.java
@@ -178,7 +178,6 @@ public QuickbaseLinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -186,6 +185,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(QuickbaseLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalSource.java
index edd662aadf3f..909a8d876212 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalSource.java
@@ -134,7 +134,6 @@ public RelationalSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalTableDataset.java
index 25bb06e02755..167ed8005374 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RelationalTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public RelationalTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model RelationalTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(RelationalTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RerunTumblingWindowTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RerunTumblingWindowTrigger.java
index 34e213bee683..5632d6af208f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RerunTumblingWindowTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RerunTumblingWindowTrigger.java
@@ -33,11 +33,6 @@ public final class RerunTumblingWindowTrigger extends Trigger {
private RerunTumblingWindowTriggerTypeProperties innerTypeProperties
= new RerunTumblingWindowTriggerTypeProperties();
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of RerunTumblingWindowTrigger class.
*/
@@ -63,17 +58,6 @@ private RerunTumblingWindowTriggerTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -197,7 +181,6 @@ public RerunTumblingWindowTrigger withRerunConcurrency(int rerunConcurrency) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -247,8 +230,8 @@ public static RerunTumblingWindowTrigger fromJson(JsonReader jsonReader) throws
if ("description".equals(fieldName)) {
deserializedRerunTumblingWindowTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedRerunTumblingWindowTrigger.runtimeState
- = TriggerRuntimeState.fromString(reader.getString());
+ deserializedRerunTumblingWindowTrigger
+ .withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedRerunTumblingWindowTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysLinkedService.java
index c1f978d09bd6..aff1360a8ffe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysLinkedService.java
@@ -282,7 +282,6 @@ public ResponsysLinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -290,6 +289,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ResponsysLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysObjectDataset.java
index 93cbf7e22513..0c014853550b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public ResponsysObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ResponsysObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ResponsysObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysSource.java
index 2a82ff37eefd..11bd9de1becf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ResponsysSource.java
@@ -126,7 +126,6 @@ public ResponsysSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestResourceDataset.java
index 4f52fdb0cbff..3972ed591ef5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestResourceDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -245,12 +246,30 @@ public RestResourceDataset withPaginationRules(Map paginationRul
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model RestResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(RestResourceDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestServiceLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestServiceLinkedService.java
index b87e6c5789a3..d8a4da31b8e0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestServiceLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestServiceLinkedService.java
@@ -631,7 +631,6 @@ public SecretBase servicePrincipalEmbeddedCertPassword() {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -639,6 +638,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(RestServiceLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSink.java
index f61605ed0875..b47547148466 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSink.java
@@ -241,7 +241,6 @@ public RestSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSource.java
index eca78cd0ddc4..d74fb0b78838 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/RestSource.java
@@ -275,7 +275,6 @@ public RestSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceLinkedService.java
index 690950d94ec2..ca159244da50 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceLinkedService.java
@@ -255,7 +255,6 @@ public SalesforceLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -263,6 +262,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SalesforceLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudLinkedService.java
index aef8b9f399a1..1baf9d836390 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudLinkedService.java
@@ -285,7 +285,6 @@ public SalesforceMarketingCloudLinkedService withEncryptedCredential(String encr
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -293,6 +292,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SalesforceMarketingCloudLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudObjectDataset.java
index 4a517d9e12ac..733eab3816c2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public SalesforceMarketingCloudObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SalesforceMarketingCloudObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SalesforceMarketingCloudObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudSource.java
index 203d88d5e4f0..91bb7b931d85 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceMarketingCloudSource.java
@@ -126,7 +126,6 @@ public SalesforceMarketingCloudSource withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceObjectDataset.java
index 8498d3622877..4eb79592e749 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -149,12 +150,30 @@ public SalesforceObjectDataset withObjectApiName(Object objectApiName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SalesforceObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SalesforceObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudLinkedService.java
index 64a5f7fc4be6..9006a2f21592 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudLinkedService.java
@@ -283,7 +283,6 @@ public SalesforceServiceCloudLinkedService withEncryptedCredential(String encryp
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -291,6 +290,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SalesforceServiceCloudLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudObjectDataset.java
index bd64b128fa85..ffa228c25f9e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -149,12 +150,30 @@ public SalesforceServiceCloudObjectDataset withObjectApiName(Object objectApiNam
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SalesforceServiceCloudObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SalesforceServiceCloudObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSink.java
index 6735c490781f..d29cee0500b7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSink.java
@@ -191,7 +191,6 @@ public SalesforceServiceCloudSink withDisableMetricsCollection(Object disableMet
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSource.java
index 4b8d4f324334..6fa7fdb416b1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudSource.java
@@ -162,7 +162,6 @@ public SalesforceServiceCloudSource withDisableMetricsCollection(Object disableM
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2LinkedService.java
index db78a3b4f259..35875fee4c12 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2LinkedService.java
@@ -258,7 +258,6 @@ public SalesforceServiceCloudV2LinkedService withEncryptedCredential(String encr
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -266,6 +265,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SalesforceServiceCloudV2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2ObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2ObjectDataset.java
index 3ee518495469..e64ee02d1a93 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2ObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2ObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -174,12 +175,30 @@ public SalesforceServiceCloudV2ObjectDataset withReportId(Object reportId) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SalesforceServiceCloudV2ObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SalesforceServiceCloudV2ObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Sink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Sink.java
index 9d860c4299ba..2f27bf9c37ba 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Sink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Sink.java
@@ -191,7 +191,6 @@ public SalesforceServiceCloudV2Sink withDisableMetricsCollection(Object disableM
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Source.java
index 9fb029a52be1..2084b625d85c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceServiceCloudV2Source.java
@@ -201,7 +201,6 @@ public SalesforceServiceCloudV2Source withDisableMetricsCollection(Object disabl
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSink.java
index 348cdbf3ccc9..33df6c57b9b1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSink.java
@@ -191,7 +191,6 @@ public SalesforceSink withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSource.java
index 7055c16d59fa..d576b50e8524 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceSource.java
@@ -152,7 +152,6 @@ public SalesforceSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2LinkedService.java
index 248178f2468b..8efd74d5661e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2LinkedService.java
@@ -257,7 +257,6 @@ public SalesforceV2LinkedService withEncryptedCredential(String encryptedCredent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -265,6 +264,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SalesforceV2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2ObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2ObjectDataset.java
index 52ee78474c82..e90d939363bd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2ObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2ObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -172,12 +173,30 @@ public SalesforceV2ObjectDataset withReportId(Object reportId) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SalesforceV2ObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SalesforceV2ObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Sink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Sink.java
index a9f3ef4a1a68..04a4a27006ac 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Sink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Sink.java
@@ -191,7 +191,6 @@ public SalesforceV2Sink withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Source.java
index c848a911d414..f31880d29687 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SalesforceV2Source.java
@@ -42,6 +42,12 @@ public final class SalesforceV2Source extends TabularSource {
*/
private Object includeDeletedObjects;
+ /*
+ * Page size for each http request, too large pageSize will caused timeout, default 300,000. Type: integer (or
+ * Expression with resultType integer).
+ */
+ private Object pageSize;
+
/**
* Creates an instance of SalesforceV2Source class.
*/
@@ -130,6 +136,28 @@ public SalesforceV2Source withIncludeDeletedObjects(Object includeDeletedObjects
return this;
}
+ /**
+ * Get the pageSize property: Page size for each http request, too large pageSize will caused timeout, default
+ * 300,000. Type: integer (or Expression with resultType integer).
+ *
+ * @return the pageSize value.
+ */
+ public Object pageSize() {
+ return this.pageSize;
+ }
+
+ /**
+ * Set the pageSize property: Page size for each http request, too large pageSize will caused timeout, default
+ * 300,000. Type: integer (or Expression with resultType integer).
+ *
+ * @param pageSize the pageSize value to set.
+ * @return the SalesforceV2Source object itself.
+ */
+ public SalesforceV2Source withPageSize(Object pageSize) {
+ this.pageSize = pageSize;
+ return this;
+ }
+
/**
* {@inheritDoc}
*/
@@ -191,7 +219,6 @@ public SalesforceV2Source withDisableMetricsCollection(Object disableMetricsColl
*/
@Override
public void validate() {
- super.validate();
}
/**
@@ -210,6 +237,7 @@ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
jsonWriter.writeUntypedField("SOQLQuery", this.soqlQuery);
jsonWriter.writeUntypedField("query", this.query);
jsonWriter.writeUntypedField("includeDeletedObjects", this.includeDeletedObjects);
+ jsonWriter.writeUntypedField("pageSize", this.pageSize);
if (additionalProperties() != null) {
for (Map.Entry additionalProperty : additionalProperties().entrySet()) {
jsonWriter.writeUntypedField(additionalProperty.getKey(), additionalProperty.getValue());
@@ -254,6 +282,8 @@ public static SalesforceV2Source fromJson(JsonReader jsonReader) throws IOExcept
deserializedSalesforceV2Source.query = reader.readUntyped();
} else if ("includeDeletedObjects".equals(fieldName)) {
deserializedSalesforceV2Source.includeDeletedObjects = reader.readUntyped();
+ } else if ("pageSize".equals(fieldName)) {
+ deserializedSalesforceV2Source.pageSize = reader.readUntyped();
} else {
if (additionalProperties == null) {
additionalProperties = new LinkedHashMap<>();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBWLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBWLinkedService.java
index 083b386a7602..a2d469cbb491 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBWLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBWLinkedService.java
@@ -253,7 +253,6 @@ public SapBWLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -261,6 +260,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapBWLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwCubeDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwCubeDataset.java
index 2a9e629b9fe8..9d3b48a10c1f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwCubeDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwCubeDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -109,9 +110,27 @@ public SapBwCubeDataset withFolder(DatasetFolder folder) {
*/
@Override
public void validate() {
- super.validate();
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SapBwCubeDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SapBwCubeDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwSource.java
index 7cb05095627d..2893fe430b75 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapBwSource.java
@@ -124,7 +124,6 @@ public SapBwSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerLinkedService.java
index 23293b9f4674..48ca9674f6cc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerLinkedService.java
@@ -208,7 +208,6 @@ public SapCloudForCustomerLinkedService withEncryptedCredential(String encrypted
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -216,6 +215,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapCloudForCustomerLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerResourceDataset.java
index 765f8df37c1a..7f52ef4a4551 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerResourceDataset.java
@@ -151,7 +151,6 @@ public SapCloudForCustomerResourceDataset withPath(Object path) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -159,6 +158,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SapCloudForCustomerResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapCloudForCustomerResourceDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSink.java
index 12d1ed3eeab8..d23ee51d1f20 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSink.java
@@ -155,7 +155,6 @@ public SapCloudForCustomerSink withDisableMetricsCollection(Object disableMetric
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSource.java
index 4de9e87a3308..7a25edc9338d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapCloudForCustomerSource.java
@@ -157,7 +157,6 @@ public SapCloudForCustomerSource withDisableMetricsCollection(Object disableMetr
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccLinkedService.java
index 70b1c20c4e90..4ca3cb19d672 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccLinkedService.java
@@ -207,7 +207,6 @@ public SapEccLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -215,6 +214,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapEccLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccResourceDataset.java
index b6e79a4d86ce..7e782a5131c9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccResourceDataset.java
@@ -148,7 +148,6 @@ public SapEccResourceDataset withPath(Object path) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -156,6 +155,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SapEccResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapEccResourceDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccSource.java
index e07e16825147..928ffb82015c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapEccSource.java
@@ -157,7 +157,6 @@ public SapEccSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaLinkedService.java
index 7743e8bd33ab..e9f59479a70c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaLinkedService.java
@@ -251,7 +251,6 @@ public SapHanaLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -259,6 +258,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapHanaLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaSource.java
index baf02b7f5d29..f61d33fbfbd8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaSource.java
@@ -204,7 +204,6 @@ public SapHanaSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaTableDataset.java
index f599d0af1bfc..9744b9364bb6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapHanaTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -170,12 +171,30 @@ public SapHanaTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SapHanaTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SapHanaTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpLinkedService.java
index 14fed060a8c6..0aae948be492 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpLinkedService.java
@@ -553,7 +553,6 @@ public SapOdpLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -561,6 +560,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapOdpLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpResourceDataset.java
index ce4230c0afaa..1b2bcc6336f8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpResourceDataset.java
@@ -171,7 +171,6 @@ public SapOdpResourceDataset withObjectName(Object objectName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -179,6 +178,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SapOdpResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapOdpResourceDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpSource.java
index 6726f67f7336..0760bad5e140 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOdpSource.java
@@ -210,7 +210,6 @@ public SapOdpSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubLinkedService.java
index d163ce17d696..9e63d0fc6655 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubLinkedService.java
@@ -383,7 +383,6 @@ public SapOpenHubLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -391,6 +390,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapOpenHubLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubSource.java
index 72743ee7e33d..d3e537ec4346 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubSource.java
@@ -213,7 +213,6 @@ public SapOpenHubSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubTableDataset.java
index 310ac25abc54..f9002bdaf710 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapOpenHubTableDataset.java
@@ -202,7 +202,6 @@ public SapOpenHubTableDataset withBaseRequestId(Object baseRequestId) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -210,6 +209,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SapOpenHubTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapOpenHubTableDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableLinkedService.java
index 4af5411c469e..073066386a46 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableLinkedService.java
@@ -505,7 +505,6 @@ public SapTableLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -513,6 +512,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapTableLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableResourceDataset.java
index 0f732b6d7cdf..fd6830892a1c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableResourceDataset.java
@@ -148,7 +148,6 @@ public SapTableResourceDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -156,6 +155,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SapTableResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SapTableResourceDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableSource.java
index 06a2ac6bacdc..ace6eac57529 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SapTableSource.java
@@ -349,7 +349,6 @@ public SapTableSource withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScheduleTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScheduleTrigger.java
index 2868eb9fe049..a38935f78d52 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScheduleTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScheduleTrigger.java
@@ -30,11 +30,6 @@ public final class ScheduleTrigger extends MultiplePipelineTrigger {
*/
private ScheduleTriggerTypeProperties innerTypeProperties = new ScheduleTriggerTypeProperties();
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of ScheduleTrigger class.
*/
@@ -60,17 +55,6 @@ private ScheduleTriggerTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -128,7 +112,6 @@ public ScheduleTrigger withRecurrence(ScheduleTriggerRecurrence recurrence) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -136,6 +119,9 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (pipelines() != null) {
+ pipelines().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ScheduleTrigger.class);
@@ -179,7 +165,7 @@ public static ScheduleTrigger fromJson(JsonReader jsonReader) throws IOException
if ("description".equals(fieldName)) {
deserializedScheduleTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedScheduleTrigger.runtimeState = TriggerRuntimeState.fromString(reader.getString());
+ deserializedScheduleTrigger.withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedScheduleTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScriptActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScriptActivity.java
index 9bfbcb9c433c..ab29a33979fe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScriptActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ScriptActivity.java
@@ -198,6 +198,33 @@ public ScriptActivity withLogSettings(ScriptActivityTypePropertiesLogSettings lo
return this;
}
+ /**
+ * Get the returnMultistatementResult property: Enable to retrieve result sets from multiple SQL statements and the
+ * number of rows affected by the DML statement. Supported connector: SnowflakeV2. Type: boolean (or Expression with
+ * resultType boolean).
+ *
+ * @return the returnMultistatementResult value.
+ */
+ public Object returnMultistatementResult() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().returnMultistatementResult();
+ }
+
+ /**
+ * Set the returnMultistatementResult property: Enable to retrieve result sets from multiple SQL statements and the
+ * number of rows affected by the DML statement. Supported connector: SnowflakeV2. Type: boolean (or Expression with
+ * resultType boolean).
+ *
+ * @param returnMultistatementResult the returnMultistatementResult value to set.
+ * @return the ScriptActivity object itself.
+ */
+ public ScriptActivity withReturnMultistatementResult(Object returnMultistatementResult) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new ScriptActivityTypeProperties();
+ }
+ this.innerTypeProperties().withReturnMultistatementResult(returnMultistatementResult);
+ return this;
+ }
+
/**
* Validates the instance.
*
@@ -205,7 +232,6 @@ public ScriptActivity withLogSettings(ScriptActivityTypePropertiesLogSettings lo
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -213,6 +239,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model ScriptActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ScriptActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SecureString.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SecureString.java
index 39bcd5dee351..ba0ac95affac 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SecureString.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SecureString.java
@@ -70,7 +70,6 @@ public SecureString withValue(String value) {
*/
@Override
public void validate() {
- super.validate();
if (value() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException("Missing required property value in model SecureString"));
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfDependencyTumblingWindowTriggerReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfDependencyTumblingWindowTriggerReference.java
index 9e4ee894603a..b33af3266f0a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfDependencyTumblingWindowTriggerReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfDependencyTumblingWindowTriggerReference.java
@@ -97,7 +97,6 @@ public SelfDependencyTumblingWindowTriggerReference withSize(String size) {
*/
@Override
public void validate() {
- super.validate();
if (offset() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntime.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntime.java
index aa67952501b4..f590f30fef17 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntime.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntime.java
@@ -123,7 +123,6 @@ public Boolean selfContainedInteractiveAuthoringEnabled() {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntimeStatus.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntimeStatus.java
index 983da1801de6..c037da4dc7b1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntimeStatus.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SelfHostedIntegrationRuntimeStatus.java
@@ -33,16 +33,6 @@ public final class SelfHostedIntegrationRuntimeStatus extends IntegrationRuntime
private SelfHostedIntegrationRuntimeStatusTypeProperties innerTypeProperties
= new SelfHostedIntegrationRuntimeStatusTypeProperties();
- /*
- * The data factory name which the integration runtime belong to.
- */
- private String dataFactoryName;
-
- /*
- * The state of integration runtime.
- */
- private IntegrationRuntimeState state;
-
/**
* Creates an instance of SelfHostedIntegrationRuntimeStatus class.
*/
@@ -68,26 +58,6 @@ private SelfHostedIntegrationRuntimeStatusTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the dataFactoryName property: The data factory name which the integration runtime belong to.
- *
- * @return the dataFactoryName value.
- */
- @Override
- public String dataFactoryName() {
- return this.dataFactoryName;
- }
-
- /**
- * Get the state property: The state of integration runtime.
- *
- * @return the state value.
- */
- @Override
- public IntegrationRuntimeState state() {
- return this.state;
- }
-
/**
* Get the createTime property: The time at which the integration runtime was created, in ISO8601 format.
*
@@ -284,7 +254,6 @@ public Boolean selfContainedInteractiveAuthoringEnabled() {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -331,10 +300,10 @@ public static SelfHostedIntegrationRuntimeStatus fromJson(JsonReader jsonReader)
reader.nextToken();
if ("dataFactoryName".equals(fieldName)) {
- deserializedSelfHostedIntegrationRuntimeStatus.dataFactoryName = reader.getString();
+ deserializedSelfHostedIntegrationRuntimeStatus.withDataFactoryName(reader.getString());
} else if ("state".equals(fieldName)) {
- deserializedSelfHostedIntegrationRuntimeStatus.state
- = IntegrationRuntimeState.fromString(reader.getString());
+ deserializedSelfHostedIntegrationRuntimeStatus
+ .withState(IntegrationRuntimeState.fromString(reader.getString()));
} else if ("typeProperties".equals(fieldName)) {
deserializedSelfHostedIntegrationRuntimeStatus.innerTypeProperties
= SelfHostedIntegrationRuntimeStatusTypeProperties.fromJson(reader);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowLinkedService.java
index f8ae099ffc3e..e6432d07e759 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowLinkedService.java
@@ -347,7 +347,6 @@ public ServiceNowLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -355,6 +354,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ServiceNowLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowObjectDataset.java
index 34fd2fec017e..d19a1d67857d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public ServiceNowObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ServiceNowObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ServiceNowObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowSource.java
index d8f27b9d9c47..0d7c7637c478 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowSource.java
@@ -126,7 +126,6 @@ public ServiceNowSource withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2LinkedService.java
index 22cd0cbbf4f4..4f6077841f8c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2LinkedService.java
@@ -295,7 +295,6 @@ public ServiceNowV2LinkedService withEncryptedCredential(String encryptedCredent
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -303,6 +302,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ServiceNowV2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2ObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2ObjectDataset.java
index 51f2194eb5e6..a7e309d20357 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2ObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2ObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public ServiceNowV2ObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ServiceNowV2ObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ServiceNowV2ObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2Source.java
index a4266ea79306..2198c9cd81fb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServiceNowV2Source.java
@@ -27,6 +27,11 @@ public final class ServiceNowV2Source extends TabularSource {
*/
private ExpressionV2 expression;
+ /*
+ * Page size of the result. Type: integer (or Expression with resultType integer).
+ */
+ private Object pageSize;
+
/**
* Creates an instance of ServiceNowV2Source class.
*/
@@ -63,6 +68,26 @@ public ServiceNowV2Source withExpression(ExpressionV2 expression) {
return this;
}
+ /**
+ * Get the pageSize property: Page size of the result. Type: integer (or Expression with resultType integer).
+ *
+ * @return the pageSize value.
+ */
+ public Object pageSize() {
+ return this.pageSize;
+ }
+
+ /**
+ * Set the pageSize property: Page size of the result. Type: integer (or Expression with resultType integer).
+ *
+ * @param pageSize the pageSize value to set.
+ * @return the ServiceNowV2Source object itself.
+ */
+ public ServiceNowV2Source withPageSize(Object pageSize) {
+ this.pageSize = pageSize;
+ return this;
+ }
+
/**
* {@inheritDoc}
*/
@@ -124,7 +149,6 @@ public ServiceNowV2Source withDisableMetricsCollection(Object disableMetricsColl
*/
@Override
public void validate() {
- super.validate();
if (expression() != null) {
expression().validate();
}
@@ -144,6 +168,7 @@ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
jsonWriter.writeUntypedField("additionalColumns", additionalColumns());
jsonWriter.writeStringField("type", this.type);
jsonWriter.writeJsonField("expression", this.expression);
+ jsonWriter.writeUntypedField("pageSize", this.pageSize);
if (additionalProperties() != null) {
for (Map.Entry additionalProperty : additionalProperties().entrySet()) {
jsonWriter.writeUntypedField(additionalProperty.getKey(), additionalProperty.getValue());
@@ -184,6 +209,8 @@ public static ServiceNowV2Source fromJson(JsonReader jsonReader) throws IOExcept
deserializedServiceNowV2Source.type = reader.getString();
} else if ("expression".equals(fieldName)) {
deserializedServiceNowV2Source.expression = ExpressionV2.fromJson(reader);
+ } else if ("pageSize".equals(fieldName)) {
+ deserializedServiceNowV2Source.pageSize = reader.readUntyped();
} else {
if (additionalProperties == null) {
additionalProperties = new LinkedHashMap<>();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServicePrincipalCredential.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServicePrincipalCredential.java
index e6213da33588..b7a4867dcb42 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServicePrincipalCredential.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ServicePrincipalCredential.java
@@ -150,7 +150,6 @@ public ServicePrincipalCredential withTenant(Object tenant) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SetVariableActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SetVariableActivity.java
index e443d71bcee8..5653d1e7c835 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SetVariableActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SetVariableActivity.java
@@ -210,7 +210,6 @@ public SetVariableActivity withSetSystemVariable(Boolean setSystemVariable) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -221,6 +220,16 @@ public void validate() {
if (policy() != null) {
policy().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model SetVariableActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SetVariableActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpLocation.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpLocation.java
index 83afae995d1e..7b3a54fcef9a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpLocation.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpLocation.java
@@ -63,7 +63,6 @@ public SftpLocation withFileName(Object fileName) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpReadSettings.java
index 4de0358c281d..a197e5ee4157 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpReadSettings.java
@@ -335,7 +335,6 @@ public SftpReadSettings withDisableMetricsCollection(Object disableMetricsCollec
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpServerLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpServerLinkedService.java
index 38c1b97a469e..2634b87f3688 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpServerLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpServerLinkedService.java
@@ -380,7 +380,6 @@ public SftpServerLinkedService withHostKeyFingerprint(Object hostKeyFingerprint)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -388,6 +387,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SftpServerLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpWriteSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpWriteSettings.java
index 774c0d73e36f..f7f430f8ac11 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpWriteSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SftpWriteSettings.java
@@ -138,7 +138,9 @@ public SftpWriteSettings withMetadata(List metadata) {
*/
@Override
public void validate() {
- super.validate();
+ if (metadata() != null) {
+ metadata().forEach(e -> e.validate());
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListLinkedService.java
index ed8fd7f846c4..7c37f6d98e5b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListLinkedService.java
@@ -317,7 +317,6 @@ public SharePointOnlineListLinkedService withEncryptedCredential(String encrypte
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -325,6 +324,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SharePointOnlineListLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListResourceDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListResourceDataset.java
index 726d4fc54089..fb0bbdfaa9d9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListResourceDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListResourceDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -149,12 +150,30 @@ public SharePointOnlineListResourceDataset withListName(Object listName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SharePointOnlineListResourceDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SharePointOnlineListResourceDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListSource.java
index 2f9e06504a9b..e92445e92c26 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SharePointOnlineListSource.java
@@ -139,7 +139,6 @@ public SharePointOnlineListSource withDisableMetricsCollection(Object disableMet
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyLinkedService.java
index 55fd60cf3034..442b3793e4e1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyLinkedService.java
@@ -255,7 +255,6 @@ public ShopifyLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -263,6 +262,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ShopifyLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyObjectDataset.java
index 201dbbfaa0c6..2d8eb9972685 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifyObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public ShopifyObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ShopifyObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ShopifyObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifySource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifySource.java
index 656c54604fdf..4c81029dfb7c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifySource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ShopifySource.java
@@ -126,7 +126,6 @@ public ShopifySource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SmartsheetLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SmartsheetLinkedService.java
index 8b0c07060d38..25fa05f71fe7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SmartsheetLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SmartsheetLinkedService.java
@@ -155,7 +155,6 @@ public SmartsheetLinkedService withEncryptedCredential(String encryptedCredentia
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -163,6 +162,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SmartsheetLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeDataset.java
index 2299f8e006be..e4bff5e54f7f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeDataset.java
@@ -175,7 +175,6 @@ public SnowflakeDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -183,6 +182,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SnowflakeDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SnowflakeDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeExportCopyCommand.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeExportCopyCommand.java
index 6b75dab68484..850ef7e352e3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeExportCopyCommand.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeExportCopyCommand.java
@@ -135,7 +135,6 @@ public SnowflakeExportCopyCommand withStorageIntegration(Object storageIntegrati
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeImportCopyCommand.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeImportCopyCommand.java
index 509767daa976..a228f77f05b7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeImportCopyCommand.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeImportCopyCommand.java
@@ -135,7 +135,6 @@ public SnowflakeImportCopyCommand withStorageIntegration(Object storageIntegrati
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeLinkedService.java
index 7b3266ff6976..69ee59b76d95 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeLinkedService.java
@@ -178,7 +178,6 @@ public SnowflakeLinkedService withEncryptedCredential(String encryptedCredential
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -186,6 +185,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SnowflakeLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSink.java
index ea8338b74de7..e34def021ab9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSink.java
@@ -149,7 +149,6 @@ public SnowflakeSink withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
if (importSettings() != null) {
importSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSource.java
index 4dfcb36c60a4..3ca4fb5e0764 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeSource.java
@@ -132,7 +132,6 @@ public SnowflakeSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
if (exportSettings() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException("Missing required property exportSettings in model SnowflakeSource"));
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Dataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Dataset.java
index 3b9d3f1119ab..3e4516fdad39 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Dataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Dataset.java
@@ -175,7 +175,6 @@ public SnowflakeV2Dataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -183,6 +182,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SnowflakeV2Dataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SnowflakeV2Dataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2LinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2LinkedService.java
index 1617a5873099..cc0de16af74d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2LinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2LinkedService.java
@@ -388,6 +388,29 @@ public SnowflakeV2LinkedService withPrivateKeyPassphrase(SecretBase privateKeyPa
return this;
}
+ /**
+ * Get the host property: The host name of the Snowflake account.
+ *
+ * @return the host value.
+ */
+ public Object host() {
+ return this.innerTypeProperties() == null ? null : this.innerTypeProperties().host();
+ }
+
+ /**
+ * Set the host property: The host name of the Snowflake account.
+ *
+ * @param host the host value to set.
+ * @return the SnowflakeV2LinkedService object itself.
+ */
+ public SnowflakeV2LinkedService withHost(Object host) {
+ if (this.innerTypeProperties() == null) {
+ this.innerTypeProperties = new SnowflakeLinkedV2ServiceTypeProperties();
+ }
+ this.innerTypeProperties().withHost(host);
+ return this;
+ }
+
/**
* Get the encryptedCredential property: The encrypted credential used for authentication. Credentials are encrypted
* using the integration runtime credential manager. Type: string.
@@ -420,7 +443,6 @@ public SnowflakeV2LinkedService withEncryptedCredential(String encryptedCredenti
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -428,6 +450,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SnowflakeV2LinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Sink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Sink.java
index 98f0d50391b9..a1373912a1fe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Sink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Sink.java
@@ -149,7 +149,6 @@ public SnowflakeV2Sink withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
if (importSettings() != null) {
importSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Source.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Source.java
index d7e53901c47a..432e2aa06736 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Source.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SnowflakeV2Source.java
@@ -132,7 +132,6 @@ public SnowflakeV2Source withDisableMetricsCollection(Object disableMetricsColle
*/
@Override
public void validate() {
- super.validate();
if (exportSettings() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkLinkedService.java
index 7d998c458cf9..55c2ab87a7be 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkLinkedService.java
@@ -443,7 +443,6 @@ public SparkLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -451,6 +450,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SparkLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkObjectDataset.java
index 9d10a247eaef..9aa74f013ec9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public SparkObjectDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SparkObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SparkObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkSource.java
index 485ae3477e2a..01baf5a0d466 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SparkSource.java
@@ -126,7 +126,6 @@ public SparkSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSink.java
index c5d03b0a7225..3731b6c5896b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSink.java
@@ -338,7 +338,6 @@ public SqlDWSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (polyBaseSettings() != null) {
polyBaseSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSource.java
index 249f2b25150a..f92591f97b30 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlDWSource.java
@@ -270,7 +270,6 @@ public SqlDWSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISink.java
index e7c33816b5d8..3a17dc81461c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISink.java
@@ -335,7 +335,6 @@ public SqlMISink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (upsertSettings() != null) {
upsertSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISource.java
index 177dc0bb048c..1df8a966c486 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlMISource.java
@@ -292,7 +292,6 @@ public SqlMISource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerLinkedService.java
index 0e30a44f2ef7..73248bb7bf20 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerLinkedService.java
@@ -773,7 +773,6 @@ public SqlServerLinkedService withPooling(Object pooling) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -781,6 +780,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SqlServerLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSink.java
index f9adf973ed62..9b7b0db55ee7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSink.java
@@ -335,7 +335,6 @@ public SqlServerSink withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
if (upsertSettings() != null) {
upsertSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSource.java
index ca2190064095..9db4d5ac4c44 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerSource.java
@@ -290,7 +290,6 @@ public SqlServerSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerStoredProcedureActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerStoredProcedureActivity.java
index 33fb0e966ad2..598be10200d0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerStoredProcedureActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerStoredProcedureActivity.java
@@ -183,7 +183,6 @@ public SqlServerStoredProcedureActivity withStoredProcedureParameters(Object sto
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -191,6 +190,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model SqlServerStoredProcedureActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SqlServerStoredProcedureActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerTableDataset.java
index c06fd03f6ac3..b03abe5ee284 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlServerTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -199,12 +200,30 @@ public SqlServerTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SqlServerTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SqlServerTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSink.java
index 9b6d72a6a31f..a6d0d6621c43 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSink.java
@@ -335,7 +335,6 @@ public SqlSink withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (upsertSettings() != null) {
upsertSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSource.java
index 00fee4021d0e..cd63dc8e61e9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SqlSource.java
@@ -265,7 +265,6 @@ public SqlSource withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareLinkedService.java
index 8fd2c3461661..66e26a2c55c6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareLinkedService.java
@@ -326,7 +326,6 @@ public SquareLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -334,6 +333,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SquareLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareObjectDataset.java
index 7180cedf1c9c..c443f0c88e86 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public SquareObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SquareObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SquareObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareSource.java
index a73ba05dc57e..c1a336e329c2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SquareSource.java
@@ -126,7 +126,6 @@ public SquareSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisEnvironment.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisEnvironment.java
index 6e5efbce0abc..b58230ac1e5c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisEnvironment.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisEnvironment.java
@@ -121,7 +121,6 @@ public SsisEnvironment withDescription(String description) {
*/
@Override
public void validate() {
- super.validate();
if (variables() != null) {
variables().forEach(e -> e.validate());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisFolder.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisFolder.java
index 6aa9f2838b6a..c955d7eb321f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisFolder.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisFolder.java
@@ -70,7 +70,6 @@ public SsisFolder withDescription(String description) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisPackage.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisPackage.java
index 16e9f1002361..65c5a2f7ed2d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisPackage.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisPackage.java
@@ -171,7 +171,6 @@ public SsisPackage withDescription(String description) {
*/
@Override
public void validate() {
- super.validate();
if (parameters() != null) {
parameters().forEach(e -> e.validate());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisProject.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisProject.java
index 9a9fe16e0f2d..be42f856978e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisProject.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SsisProject.java
@@ -171,7 +171,6 @@ public SsisProject withDescription(String description) {
*/
@Override
public void validate() {
- super.validate();
if (environmentRefs() != null) {
environmentRefs().forEach(e -> e.validate());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SwitchActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SwitchActivity.java
index b6278b014847..e4e9d7290ddf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SwitchActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SwitchActivity.java
@@ -192,7 +192,6 @@ public SwitchActivity withDefaultActivities(List defaultActivities) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -200,6 +199,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model SwitchActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SwitchActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseLinkedService.java
index 5a7bd035e210..5388ad0bf683 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseLinkedService.java
@@ -270,7 +270,6 @@ public SybaseLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -278,6 +277,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SybaseLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseSource.java
index 1ce82d79e123..80bfd0beddc2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseSource.java
@@ -124,7 +124,6 @@ public SybaseSource withDisableMetricsCollection(Object disableMetricsCollection
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseTableDataset.java
index c35e46d8e60f..f005730c34f3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SybaseTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public SybaseTableDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model SybaseTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(SybaseTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseNotebookActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseNotebookActivity.java
index 1bc1fea2926f..f60882b1158c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseNotebookActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseNotebookActivity.java
@@ -377,7 +377,6 @@ public SynapseNotebookActivity withSparkConfig(Map sparkConfig)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -385,6 +384,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model SynapseNotebookActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SynapseNotebookActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseSparkJobDefinitionActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseSparkJobDefinitionActivity.java
index 942d1a9207ec..ea0a907a3e61 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseSparkJobDefinitionActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/SynapseSparkJobDefinitionActivity.java
@@ -534,7 +534,6 @@ public SynapseSparkJobDefinitionActivity withSparkConfig(Map spa
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -542,6 +541,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property name in model SynapseSparkJobDefinitionActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(SynapseSparkJobDefinitionActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularSource.java
index ca43a64ff94a..20a79832fddd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularSource.java
@@ -137,7 +137,6 @@ public TabularSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularTranslator.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularTranslator.java
index 92462a26325f..e824bceec3b2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularTranslator.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TabularTranslator.java
@@ -252,7 +252,6 @@ public TabularTranslator withTypeConversionSettings(TypeConversionSettings typeC
*/
@Override
public void validate() {
- super.validate();
if (typeConversionSettings() != null) {
typeConversionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarGZipReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarGZipReadSettings.java
index e56e5a79308a..cae66ba495a4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarGZipReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarGZipReadSettings.java
@@ -72,7 +72,6 @@ public TarGZipReadSettings withPreserveCompressionFileNameAsFolder(Object preser
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarReadSettings.java
index 72e9e1858e07..cedd860a5914 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TarReadSettings.java
@@ -72,7 +72,6 @@ public TarReadSettings withPreserveCompressionFileNameAsFolder(Object preserveCo
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeamDeskLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeamDeskLinkedService.java
index 6030a3e80855..67c2293b1114 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeamDeskLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeamDeskLinkedService.java
@@ -249,7 +249,6 @@ public TeamDeskLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -257,6 +256,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(TeamDeskLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataLinkedService.java
index ef5fac335589..cf383763ee67 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataLinkedService.java
@@ -249,7 +249,6 @@ public TeradataLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -257,6 +256,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(TeradataLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataSource.java
index b01121ea3d41..6efc793c9a02 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataSource.java
@@ -177,7 +177,6 @@ public TeradataSource withDisableMetricsCollection(Object disableMetricsCollecti
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataTableDataset.java
index cc9f90ebfd53..09ad3a6a7a08 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TeradataTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -170,12 +171,30 @@ public TeradataTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model TeradataTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(TeradataTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TextFormat.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TextFormat.java
index b418b1bdfda8..a3df67f67595 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TextFormat.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TextFormat.java
@@ -308,7 +308,6 @@ public TextFormat withDeserializer(Object deserializer) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TriggerDependencyReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TriggerDependencyReference.java
index 1ede521f42e6..a4eebe2934dd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TriggerDependencyReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TriggerDependencyReference.java
@@ -69,7 +69,6 @@ public TriggerDependencyReference withReferenceTrigger(TriggerReference referenc
*/
@Override
public void validate() {
- super.validate();
if (referenceTrigger() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTrigger.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTrigger.java
index 4130a8039300..b6a91cb626ff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTrigger.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTrigger.java
@@ -37,11 +37,6 @@ public final class TumblingWindowTrigger extends Trigger {
*/
private TumblingWindowTriggerTypeProperties innerTypeProperties = new TumblingWindowTriggerTypeProperties();
- /*
- * Indicates if trigger is running or not. Updated when Start/Stop APIs are called on the Trigger.
- */
- private TriggerRuntimeState runtimeState;
-
/**
* Creates an instance of TumblingWindowTrigger class.
*/
@@ -89,17 +84,6 @@ private TumblingWindowTriggerTypeProperties innerTypeProperties() {
return this.innerTypeProperties;
}
- /**
- * Get the runtimeState property: Indicates if trigger is running or not. Updated when Start/Stop APIs are called on
- * the Trigger.
- *
- * @return the runtimeState value.
- */
- @Override
- public TriggerRuntimeState runtimeState() {
- return this.runtimeState;
- }
-
/**
* {@inheritDoc}
*/
@@ -319,7 +303,6 @@ public TumblingWindowTrigger withDependsOn(List dependsOn)
*/
@Override
public void validate() {
- super.validate();
if (pipeline() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException("Missing required property pipeline in model TumblingWindowTrigger"));
@@ -376,7 +359,8 @@ public static TumblingWindowTrigger fromJson(JsonReader jsonReader) throws IOExc
if ("description".equals(fieldName)) {
deserializedTumblingWindowTrigger.withDescription(reader.getString());
} else if ("runtimeState".equals(fieldName)) {
- deserializedTumblingWindowTrigger.runtimeState = TriggerRuntimeState.fromString(reader.getString());
+ deserializedTumblingWindowTrigger
+ .withRuntimeState(TriggerRuntimeState.fromString(reader.getString()));
} else if ("annotations".equals(fieldName)) {
List annotations = reader.readArray(reader1 -> reader1.readUntyped());
deserializedTumblingWindowTrigger.withAnnotations(annotations);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTriggerDependencyReference.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTriggerDependencyReference.java
index 5a8412e2083e..e05392ea17b0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTriggerDependencyReference.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TumblingWindowTriggerDependencyReference.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -105,9 +106,17 @@ public TumblingWindowTriggerDependencyReference withReferenceTrigger(TriggerRefe
*/
@Override
public void validate() {
- super.validate();
+ if (referenceTrigger() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property referenceTrigger in model TumblingWindowTriggerDependencyReference"));
+ } else {
+ referenceTrigger().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(TumblingWindowTriggerDependencyReference.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TwilioLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TwilioLinkedService.java
index 478d7ebf7f66..feb66b0ce441 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TwilioLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/TwilioLinkedService.java
@@ -155,7 +155,6 @@ public TwilioLinkedService withPassword(SecretBase password) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -163,6 +162,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(TwilioLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/UntilActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/UntilActivity.java
index c48b99339e3a..041fc6bbb93d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/UntilActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/UntilActivity.java
@@ -192,7 +192,6 @@ public UntilActivity withActivities(List activities) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -200,6 +199,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model UntilActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(UntilActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ValidationActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ValidationActivity.java
index 14f3d1bbd1e2..6bbbcc55971d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ValidationActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ValidationActivity.java
@@ -241,7 +241,6 @@ public ValidationActivity withDataset(DatasetReference dataset) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -249,6 +248,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model ValidationActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ValidationActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaLinkedService.java
index 90f43f8ef3db..71edabb79e0c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaLinkedService.java
@@ -272,7 +272,6 @@ public VerticaLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -280,6 +279,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(VerticaLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaSource.java
index 48a473a9829c..49aec82e4cce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaSource.java
@@ -126,7 +126,6 @@ public VerticaSource withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaTableDataset.java
index 3cf723169a77..f8d62d186f95 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/VerticaTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -195,12 +196,30 @@ public VerticaTableDataset withSchemaTypePropertiesSchema(Object schema) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model VerticaTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(VerticaTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WaitActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WaitActivity.java
index 5fbed09e1bce..2c9d962643a7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WaitActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WaitActivity.java
@@ -139,7 +139,6 @@ public WaitActivity withWaitTimeInSeconds(Object waitTimeInSeconds) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -147,6 +146,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model WaitActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WaitActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseLinkedService.java
index 6bc9e1cbe32b..217b360aaca0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseLinkedService.java
@@ -338,7 +338,6 @@ public WarehouseLinkedService withServicePrincipalCredential(SecretBase serviceP
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -346,6 +345,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WarehouseLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSink.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSink.java
index d8d4b87f26a2..ac2d01941695 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSink.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSink.java
@@ -233,7 +233,6 @@ public WarehouseSink withDisableMetricsCollection(Object disableMetricsCollectio
*/
@Override
public void validate() {
- super.validate();
if (copyCommandSettings() != null) {
copyCommandSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSource.java
index fe02ef213217..59961b1475df 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseSource.java
@@ -270,7 +270,6 @@ public WarehouseSource withDisableMetricsCollection(Object disableMetricsCollect
*/
@Override
public void validate() {
- super.validate();
if (partitionSettings() != null) {
partitionSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseTableDataset.java
index b4384c3a639e..bb627ed599f9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WarehouseTableDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -174,12 +175,30 @@ public WarehouseTableDataset withTable(Object table) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model WarehouseTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(WarehouseTableDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebActivity.java
index ac882f406b36..6fdb4d245218 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebActivity.java
@@ -401,7 +401,6 @@ public WebActivity withConnectVia(IntegrationRuntimeReference connectVia) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(
@@ -409,6 +408,22 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model WebActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
+ if (linkedServiceName() != null) {
+ linkedServiceName().validate();
+ }
+ if (policy() != null) {
+ policy().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WebActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebAnonymousAuthentication.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebAnonymousAuthentication.java
index 9a291414142e..3bb627a57d0b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebAnonymousAuthentication.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebAnonymousAuthentication.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -52,9 +53,14 @@ public WebAnonymousAuthentication withUrl(Object url) {
*/
@Override
public void validate() {
- super.validate();
+ if (url() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property url in model WebAnonymousAuthentication"));
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(WebAnonymousAuthentication.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebBasicAuthentication.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebBasicAuthentication.java
index 7c67184f52ea..5c0b529b49e1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebBasicAuthentication.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebBasicAuthentication.java
@@ -105,7 +105,6 @@ public WebBasicAuthentication withUrl(Object url) {
*/
@Override
public void validate() {
- super.validate();
if (username() == null) {
throw LOGGER.atError()
.log(
@@ -118,6 +117,10 @@ public void validate() {
} else {
password().validate();
}
+ if (url() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property url in model WebBasicAuthentication"));
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WebBasicAuthentication.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebClientCertificateAuthentication.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebClientCertificateAuthentication.java
index cce1ce665299..02a5dd6189d2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebClientCertificateAuthentication.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebClientCertificateAuthentication.java
@@ -104,7 +104,6 @@ public WebClientCertificateAuthentication withUrl(Object url) {
*/
@Override
public void validate() {
- super.validate();
if (pfx() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -119,6 +118,11 @@ public void validate() {
} else {
password().validate();
}
+ if (url() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property url in model WebClientCertificateAuthentication"));
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WebClientCertificateAuthentication.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebLinkedService.java
index a066bb5938d1..a60ba54bf6f3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebLinkedService.java
@@ -117,7 +117,6 @@ public WebLinkedService withAnnotations(List annotations) {
*/
@Override
public void validate() {
- super.validate();
if (typeProperties() == null) {
throw LOGGER.atError()
.log(
@@ -125,6 +124,16 @@ public void validate() {
} else {
typeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WebLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebSource.java
index abad61097164..6365aac73447 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebSource.java
@@ -109,7 +109,6 @@ public WebSource withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebTableDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebTableDataset.java
index bbae9bafb125..83abcef05d44 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebTableDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebTableDataset.java
@@ -175,7 +175,6 @@ public WebTableDataset withPath(Object path) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -183,6 +182,23 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model WebTableDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WebTableDataset.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebhookActivity.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebhookActivity.java
index d8e7e72a3d0a..e6429348febd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebhookActivity.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WebhookActivity.java
@@ -318,7 +318,6 @@ public WebhookActivity withReportStatusOnCallBack(Object reportStatusOnCallBack)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -329,6 +328,16 @@ public void validate() {
if (policy() != null) {
policy().validate();
}
+ if (name() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property name in model WebhookActivity"));
+ }
+ if (dependsOn() != null) {
+ dependsOn().forEach(e -> e.validate());
+ }
+ if (userProperties() != null) {
+ userProperties().forEach(e -> e.validate());
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(WebhookActivity.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WranglingDataFlow.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WranglingDataFlow.java
index 4d18529b2755..775b1722bf5c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WranglingDataFlow.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/WranglingDataFlow.java
@@ -155,10 +155,12 @@ public WranglingDataFlow withDocumentLocale(String documentLocale) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (folder() != null) {
+ folder().validate();
+ }
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroLinkedService.java
index 45c64f7f9ab7..17daf23a56a7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroLinkedService.java
@@ -305,7 +305,6 @@ public XeroLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -313,6 +312,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(XeroLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroObjectDataset.java
index aee4de980069..a5e712f225c3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public XeroObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model XeroObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(XeroObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroSource.java
index 742123b3a418..465cb11137da 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XeroSource.java
@@ -126,7 +126,6 @@ public XeroSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlDataset.java
index f9b46bd488b7..7b0bbd91bd29 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -222,12 +223,29 @@ public XmlDataset withCompression(DatasetCompression compression) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException("Missing required property linkedServiceName in model XmlDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(XmlDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlReadSettings.java
index fbdf8f21a3e1..42c7d01cb21b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlReadSettings.java
@@ -187,7 +187,6 @@ public XmlReadSettings withNamespacePrefixes(Object namespacePrefixes) {
*/
@Override
public void validate() {
- super.validate();
if (compressionProperties() != null) {
compressionProperties().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlSource.java
index 5b4970eb6282..dd14a119bbb7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/XmlSource.java
@@ -159,7 +159,6 @@ public XmlSource withDisableMetricsCollection(Object disableMetricsCollection) {
*/
@Override
public void validate() {
- super.validate();
if (storeSettings() != null) {
storeSettings().validate();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZendeskLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZendeskLinkedService.java
index 561d75db7ee7..ea0473769c69 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZendeskLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZendeskLinkedService.java
@@ -249,7 +249,6 @@ public ZendeskLinkedService withEncryptedCredential(String encryptedCredential)
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -257,6 +256,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ZendeskLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZipDeflateReadSettings.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZipDeflateReadSettings.java
index e3697b237a1f..88c3ad0641a0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZipDeflateReadSettings.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZipDeflateReadSettings.java
@@ -72,7 +72,6 @@ public ZipDeflateReadSettings withPreserveZipFileNameAsFolder(Object preserveZip
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoLinkedService.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoLinkedService.java
index a2979b3bd05e..19b6a54b1408 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoLinkedService.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoLinkedService.java
@@ -278,7 +278,6 @@ public ZohoLinkedService withEncryptedCredential(String encryptedCredential) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() == null) {
throw LOGGER.atError()
.log(new IllegalArgumentException(
@@ -286,6 +285,16 @@ public void validate() {
} else {
innerTypeProperties().validate();
}
+ if (connectVia() != null) {
+ connectVia().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
}
private static final ClientLogger LOGGER = new ClientLogger(ZohoLinkedService.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoObjectDataset.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoObjectDataset.java
index 3b6d9dc699c0..636ff6e704f3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoObjectDataset.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoObjectDataset.java
@@ -5,6 +5,7 @@
package com.azure.resourcemanager.datafactory.models;
import com.azure.core.annotation.Fluent;
+import com.azure.core.util.logging.ClientLogger;
import com.azure.json.JsonReader;
import com.azure.json.JsonToken;
import com.azure.json.JsonWriter;
@@ -147,12 +148,30 @@ public ZohoObjectDataset withTableName(Object tableName) {
*/
@Override
public void validate() {
- super.validate();
if (innerTypeProperties() != null) {
innerTypeProperties().validate();
}
+ if (linkedServiceName() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property linkedServiceName in model ZohoObjectDataset"));
+ } else {
+ linkedServiceName().validate();
+ }
+ if (parameters() != null) {
+ parameters().values().forEach(e -> {
+ if (e != null) {
+ e.validate();
+ }
+ });
+ }
+ if (folder() != null) {
+ folder().validate();
+ }
}
+ private static final ClientLogger LOGGER = new ClientLogger(ZohoObjectDataset.class);
+
/**
* {@inheritDoc}
*/
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoSource.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoSource.java
index 068afb44cf45..93588b47ec6b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoSource.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/main/java/com/azure/resourcemanager/datafactory/models/ZohoSource.java
@@ -126,7 +126,6 @@ public ZohoSource withDisableMetricsCollection(Object disableMetricsCollection)
*/
@Override
public void validate() {
- super.validate();
}
/**
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/DataFactoryTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/DataFactoryTests.java
index f81f24a1b00a..be9a16e19130 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/DataFactoryTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/DataFactoryTests.java
@@ -43,7 +43,6 @@ public class DataFactoryTests extends TestProxyTestBase {
private static final Random RANDOM = new Random();
private static final Region REGION = Region.US_WEST2;
- private static final String STORAGE_ACCOUNT = "sa" + randomPadding();
private static final String DATA_FACTORY = "df" + randomPadding();
private static String resourceGroup = "rg" + randomPadding();
@@ -67,22 +66,23 @@ public void dataFactoryTest() {
}
try {
+ final String storageAccountName = testResourceNamer.randomName("sa", 22);
// @embedmeStart
// storage account
StorageAccount storageAccount = storageManager.storageAccounts()
- .define(STORAGE_ACCOUNT)
+ .define(storageAccountName)
.withRegion(REGION)
.withExistingResourceGroup(resourceGroup)
.create();
final String storageAccountKey = storageAccount.getKeys().iterator().next().value();
final String connectionString
- = getStorageConnectionString(STORAGE_ACCOUNT, storageAccountKey, storageManager.environment());
+ = getStorageConnectionString(storageAccountName, storageAccountKey, storageManager.environment());
// container
final String containerName = "adf";
storageManager.blobContainers()
.defineContainer(containerName)
- .withExistingStorageAccount(resourceGroup, STORAGE_ACCOUNT)
+ .withExistingStorageAccount(resourceGroup, storageAccountName)
.withPublicAccess(PublicAccess.NONE)
.create();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ActivityPolicyTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ActivityPolicyTests.java
index b0020ae733b5..66b8877f487d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ActivityPolicyTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ActivityPolicyTests.java
@@ -14,25 +14,25 @@ public final class ActivityPolicyTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ActivityPolicy model = BinaryData.fromString(
- "{\"timeout\":\"datafksqfcxdleo\",\"retry\":\"datasdgkbaxygwvtkr\",\"retryIntervalInSeconds\":46399905,\"secureInput\":true,\"secureOutput\":false,\"\":{\"eipfotaaqyxk\":\"dataqztrpj\",\"q\":\"dataoabcoxqaavjkre\",\"ivianklqclftp\":\"datasviysbvo\"}}")
+ "{\"timeout\":\"datamlsuuhwuox\",\"retry\":\"datai\",\"retryIntervalInSeconds\":1056891956,\"secureInput\":true,\"secureOutput\":true,\"\":{\"xxcruleimswxoi\":\"datagzjrkslqbafdb\",\"pgzetuvfps\":\"datanqumj\",\"ks\":\"datajpmeptnqsnpa\"}}")
.toObject(ActivityPolicy.class);
- Assertions.assertEquals(46399905, model.retryIntervalInSeconds());
+ Assertions.assertEquals(1056891956, model.retryIntervalInSeconds());
Assertions.assertEquals(true, model.secureInput());
- Assertions.assertEquals(false, model.secureOutput());
+ Assertions.assertEquals(true, model.secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ActivityPolicy model = new ActivityPolicy().withTimeout("datafksqfcxdleo")
- .withRetry("datasdgkbaxygwvtkr")
- .withRetryIntervalInSeconds(46399905)
+ ActivityPolicy model = new ActivityPolicy().withTimeout("datamlsuuhwuox")
+ .withRetry("datai")
+ .withRetryIntervalInSeconds(1056891956)
.withSecureInput(true)
- .withSecureOutput(false)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(ActivityPolicy.class);
- Assertions.assertEquals(46399905, model.retryIntervalInSeconds());
+ Assertions.assertEquals(1056891956, model.retryIntervalInSeconds());
Assertions.assertEquals(true, model.secureInput());
- Assertions.assertEquals(false, model.secureOutput());
+ Assertions.assertEquals(true, model.secureOutput());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsObjectDatasetTests.java
index d692bf1cb689..2713ab94eec3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsObjectDatasetTests.java
@@ -19,36 +19,33 @@ public final class AmazonMwsObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonMwsObjectDataset model = BinaryData.fromString(
- "{\"type\":\"AmazonMWSObject\",\"typeProperties\":{\"tableName\":\"datagirrpwnqtvuxeuj\"},\"description\":\"ssijuaxxfd\",\"structure\":\"datapkcpws\",\"schema\":\"datannmjun\",\"linkedServiceName\":{\"referenceName\":\"tl\",\"parameters\":{\"kcsihxvta\":\"datatjhbcycgq\",\"zqqgug\":\"datawwfopxpryxnsbubw\"}},\"parameters\":{\"mkdhwqcqweba\":{\"type\":\"SecureString\",\"defaultValue\":\"datahtq\"},\"rgvypa\":{\"type\":\"String\",\"defaultValue\":\"datapkephujeucosvkke\"},\"ueez\":{\"type\":\"String\",\"defaultValue\":\"datapyillg\"},\"zyojfch\":{\"type\":\"Float\",\"defaultValue\":\"datafbuqxknvmcgmb\"}},\"annotations\":[\"dataarex\",\"datao\"],\"folder\":{\"name\":\"qhboojuxilozbl\"},\"\":{\"b\":\"datafldfljwt\",\"gftshfgmuxuqiags\":\"datatsflotumbm\",\"paowkgvnlfueyxfz\":\"dataoikuqirhsk\",\"ce\":\"databrlrjugcfebpi\"}}")
+ "{\"type\":\"AmazonMWSObject\",\"typeProperties\":{\"tableName\":\"datasfqqhcmecagsbf\"},\"description\":\"irpnj\",\"structure\":\"datallfkchhgs\",\"schema\":\"datazzcajl\",\"linkedServiceName\":{\"referenceName\":\"mqcycabaamkkhd\",\"parameters\":{\"ws\":\"datakxdujkxpuqzdyoq\",\"ezxiz\":\"dataarpzhry\",\"azccouhwivkd\":\"datasyxbfjilb\"}},\"parameters\":{\"dqbvx\":{\"type\":\"SecureString\",\"defaultValue\":\"datanrbxzepirtvcpi\"}},\"annotations\":[\"datalpwbopvhcbt\"],\"folder\":{\"name\":\"rjxcon\"},\"\":{\"h\":\"datakfki\",\"gvuqzgbjwvrudmp\":\"dataeoc\",\"esgyzwph\":\"dataewpmioleaja\"}}")
.toObject(AmazonMwsObjectDataset.class);
- Assertions.assertEquals("ssijuaxxfd", model.description());
- Assertions.assertEquals("tl", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("mkdhwqcqweba").type());
- Assertions.assertEquals("qhboojuxilozbl", model.folder().name());
+ Assertions.assertEquals("irpnj", model.description());
+ Assertions.assertEquals("mqcycabaamkkhd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("dqbvx").type());
+ Assertions.assertEquals("rjxcon", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonMwsObjectDataset model = new AmazonMwsObjectDataset().withDescription("ssijuaxxfd")
- .withStructure("datapkcpws")
- .withSchema("datannmjun")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tl")
- .withParameters(mapOf("kcsihxvta", "datatjhbcycgq", "zqqgug", "datawwfopxpryxnsbubw")))
- .withParameters(mapOf("mkdhwqcqweba",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datahtq"),
- "rgvypa",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datapkephujeucosvkke"),
- "ueez", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datapyillg"),
- "zyojfch",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datafbuqxknvmcgmb")))
- .withAnnotations(Arrays.asList("dataarex", "datao"))
- .withFolder(new DatasetFolder().withName("qhboojuxilozbl"))
- .withTableName("datagirrpwnqtvuxeuj");
+ AmazonMwsObjectDataset model = new AmazonMwsObjectDataset().withDescription("irpnj")
+ .withStructure("datallfkchhgs")
+ .withSchema("datazzcajl")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mqcycabaamkkhd")
+ .withParameters(
+ mapOf("ws", "datakxdujkxpuqzdyoq", "ezxiz", "dataarpzhry", "azccouhwivkd", "datasyxbfjilb")))
+ .withParameters(mapOf("dqbvx",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datanrbxzepirtvcpi")))
+ .withAnnotations(Arrays.asList("datalpwbopvhcbt"))
+ .withFolder(new DatasetFolder().withName("rjxcon"))
+ .withTableName("datasfqqhcmecagsbf");
model = BinaryData.fromObject(model).toObject(AmazonMwsObjectDataset.class);
- Assertions.assertEquals("ssijuaxxfd", model.description());
- Assertions.assertEquals("tl", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("mkdhwqcqweba").type());
- Assertions.assertEquals("qhboojuxilozbl", model.folder().name());
+ Assertions.assertEquals("irpnj", model.description());
+ Assertions.assertEquals("mqcycabaamkkhd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("dqbvx").type());
+ Assertions.assertEquals("rjxcon", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsSourceTests.java
index 51a5f763d39d..790b4414dfa9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonMwsSourceTests.java
@@ -11,19 +11,19 @@ public final class AmazonMwsSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonMwsSource model = BinaryData.fromString(
- "{\"type\":\"AmazonMWSSource\",\"query\":\"dataj\",\"queryTimeout\":\"datap\",\"additionalColumns\":\"datavhfpfsesiywcre\",\"sourceRetryCount\":\"dataphqqozhesbpq\",\"sourceRetryWait\":\"datamfjktd\",\"maxConcurrentConnections\":\"datahlkzt\",\"disableMetricsCollection\":\"datauuupcdaoatzvajw\",\"\":{\"lmazgpqo\":\"dataefmotulh\"}}")
+ "{\"type\":\"AmazonMWSSource\",\"query\":\"datakujceeczhsdpfoa\",\"queryTimeout\":\"dataahuwxodddqz\",\"additionalColumns\":\"datarrytgsocqkdc\",\"sourceRetryCount\":\"datazqnaoxsgmpdcb\",\"sourceRetryWait\":\"datazautuaysxhfupvq\",\"maxConcurrentConnections\":\"dataqlafi\",\"disableMetricsCollection\":\"dataw\",\"\":{\"mgaifgy\":\"datapuyefhhd\",\"hxpcxqc\":\"datakgqwmp\",\"dhx\":\"datankxhc\"}}")
.toObject(AmazonMwsSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonMwsSource model = new AmazonMwsSource().withSourceRetryCount("dataphqqozhesbpq")
- .withSourceRetryWait("datamfjktd")
- .withMaxConcurrentConnections("datahlkzt")
- .withDisableMetricsCollection("datauuupcdaoatzvajw")
- .withQueryTimeout("datap")
- .withAdditionalColumns("datavhfpfsesiywcre")
- .withQuery("dataj");
+ AmazonMwsSource model = new AmazonMwsSource().withSourceRetryCount("datazqnaoxsgmpdcb")
+ .withSourceRetryWait("datazautuaysxhfupvq")
+ .withMaxConcurrentConnections("dataqlafi")
+ .withDisableMetricsCollection("dataw")
+ .withQueryTimeout("dataahuwxodddqz")
+ .withAdditionalColumns("datarrytgsocqkdc")
+ .withQuery("datakujceeczhsdpfoa");
model = BinaryData.fromObject(model).toObject(AmazonMwsSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOraclePartitionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOraclePartitionSettingsTests.java
index dfb35e58c3a6..6c5a5822f5d9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOraclePartitionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOraclePartitionSettingsTests.java
@@ -11,17 +11,17 @@ public final class AmazonRdsForOraclePartitionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRdsForOraclePartitionSettings model = BinaryData.fromString(
- "{\"partitionNames\":\"datahq\",\"partitionColumnName\":\"datazgzmonjqnienctw\",\"partitionUpperBound\":\"datamhfmognn\",\"partitionLowerBound\":\"datardllrqamfj\"}")
+ "{\"partitionNames\":\"datajnsp\",\"partitionColumnName\":\"dataqo\",\"partitionUpperBound\":\"datautqt\",\"partitionLowerBound\":\"dataivvnmavfzjwdwwnx\"}")
.toObject(AmazonRdsForOraclePartitionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AmazonRdsForOraclePartitionSettings model
- = new AmazonRdsForOraclePartitionSettings().withPartitionNames("datahq")
- .withPartitionColumnName("datazgzmonjqnienctw")
- .withPartitionUpperBound("datamhfmognn")
- .withPartitionLowerBound("datardllrqamfj");
+ = new AmazonRdsForOraclePartitionSettings().withPartitionNames("datajnsp")
+ .withPartitionColumnName("dataqo")
+ .withPartitionUpperBound("datautqt")
+ .withPartitionLowerBound("dataivvnmavfzjwdwwnx");
model = BinaryData.fromObject(model).toObject(AmazonRdsForOraclePartitionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleSourceTests.java
index 106ed0c112f5..99406d66d20c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleSourceTests.java
@@ -12,24 +12,24 @@ public final class AmazonRdsForOracleSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRdsForOracleSource model = BinaryData.fromString(
- "{\"type\":\"AmazonRdsForOracleSource\",\"oracleReaderQuery\":\"datayrdy\",\"queryTimeout\":\"datawgikpdpudqiwhvx\",\"partitionOption\":\"datavpoeuufw\",\"partitionSettings\":{\"partitionNames\":\"dataeffrb\",\"partitionColumnName\":\"datajedycjisxsp\",\"partitionUpperBound\":\"datafydphl\",\"partitionLowerBound\":\"datano\"},\"additionalColumns\":\"databdvjlqfzlbpeh\",\"sourceRetryCount\":\"datapgllrh\",\"sourceRetryWait\":\"dataxstpg\",\"maxConcurrentConnections\":\"databezmyjqpdchds\",\"disableMetricsCollection\":\"datakmgppxzgjysmtskt\",\"\":{\"wddpjsokos\":\"datay\",\"zfwdmae\":\"datagrf\"}}")
+ "{\"type\":\"AmazonRdsForOracleSource\",\"oracleReaderQuery\":\"datav\",\"queryTimeout\":\"datai\",\"partitionOption\":\"datajhxxxuuqcmunhfa\",\"partitionSettings\":{\"partitionNames\":\"datanyvypu\",\"partitionColumnName\":\"dataxhowwe\",\"partitionUpperBound\":\"datayw\",\"partitionLowerBound\":\"datahiuwv\"},\"additionalColumns\":\"datagejytqnzrcbh\",\"sourceRetryCount\":\"datahctjvlwfnzgz\",\"sourceRetryWait\":\"datafyvytydrdcwbaiaq\",\"maxConcurrentConnections\":\"datauhsmuclx\",\"disableMetricsCollection\":\"dataedusu\",\"\":{\"ibrolqxloed\":\"datavykagsxhzhervv\",\"fsyq\":\"datazrvf\",\"owthvuepszzn\":\"datafgwuj\"}}")
.toObject(AmazonRdsForOracleSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonRdsForOracleSource model = new AmazonRdsForOracleSource().withSourceRetryCount("datapgllrh")
- .withSourceRetryWait("dataxstpg")
- .withMaxConcurrentConnections("databezmyjqpdchds")
- .withDisableMetricsCollection("datakmgppxzgjysmtskt")
- .withOracleReaderQuery("datayrdy")
- .withQueryTimeout("datawgikpdpudqiwhvx")
- .withPartitionOption("datavpoeuufw")
- .withPartitionSettings(new AmazonRdsForOraclePartitionSettings().withPartitionNames("dataeffrb")
- .withPartitionColumnName("datajedycjisxsp")
- .withPartitionUpperBound("datafydphl")
- .withPartitionLowerBound("datano"))
- .withAdditionalColumns("databdvjlqfzlbpeh");
+ AmazonRdsForOracleSource model = new AmazonRdsForOracleSource().withSourceRetryCount("datahctjvlwfnzgz")
+ .withSourceRetryWait("datafyvytydrdcwbaiaq")
+ .withMaxConcurrentConnections("datauhsmuclx")
+ .withDisableMetricsCollection("dataedusu")
+ .withOracleReaderQuery("datav")
+ .withQueryTimeout("datai")
+ .withPartitionOption("datajhxxxuuqcmunhfa")
+ .withPartitionSettings(new AmazonRdsForOraclePartitionSettings().withPartitionNames("datanyvypu")
+ .withPartitionColumnName("dataxhowwe")
+ .withPartitionUpperBound("datayw")
+ .withPartitionLowerBound("datahiuwv"))
+ .withAdditionalColumns("datagejytqnzrcbh");
model = BinaryData.fromObject(model).toObject(AmazonRdsForOracleSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTests.java
index 2f9fe4d017e7..1106b6c3309f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTests.java
@@ -19,35 +19,33 @@ public final class AmazonRdsForOracleTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRdsForOracleTableDataset model = BinaryData.fromString(
- "{\"type\":\"AmazonRdsForOracleTable\",\"typeProperties\":{\"schema\":\"datawcjomipvw\",\"table\":\"dataujttwykoxvbw\"},\"description\":\"xxdplrelfkvga\",\"structure\":\"databtuxlbpxrhrfje\",\"schema\":\"dataazwef\",\"linkedServiceName\":{\"referenceName\":\"ktlhqash\",\"parameters\":{\"tacfvvtdpcbp\":\"datatjixyzsecigzzdw\",\"brhfiwltkfysunte\":\"datafomcsau\",\"whcv\":\"datahkl\",\"xyxxhwr\":\"datasyyhgqokjbmsrk\"}},\"parameters\":{\"ozsxagyso\":{\"type\":\"Float\",\"defaultValue\":\"dataqsyilpzzbrwnr\"},\"vrrbnhy\":{\"type\":\"Int\",\"defaultValue\":\"dataiksy\"},\"dyllm\":{\"type\":\"Float\",\"defaultValue\":\"datahujc\"}},\"annotations\":[\"datastizsyqag\",\"datallcbrva\",\"datadylkyhtr\",\"dataqwfyybptmjjr\"],\"folder\":{\"name\":\"ykugdla\"},\"\":{\"kbzbfbxjb\":\"datavgthkslgeuu\",\"sazdjmofsvpz\":\"dataajybdnbycsbto\",\"mlfjymgw\":\"datagnywxu\"}}")
+ "{\"type\":\"AmazonRdsForOracleTable\",\"typeProperties\":{\"schema\":\"datankfrwxo\",\"table\":\"dataydsn\"},\"description\":\"pchiypbfhmih\",\"structure\":\"datatqozewbrsrjzgkbr\",\"schema\":\"dataxboufqnnqbjx\",\"linkedServiceName\":{\"referenceName\":\"jwsreruk\",\"parameters\":{\"wkjxlaaced\":\"datadrizw\",\"lssybzbev\":\"datakq\"}},\"parameters\":{\"jy\":{\"type\":\"Int\",\"defaultValue\":\"datammkiqhypwtmzy\"},\"i\":{\"type\":\"String\",\"defaultValue\":\"datamzqlnaag\"}},\"annotations\":[\"datafqiywhxpsb\",\"datapialezay\"],\"folder\":{\"name\":\"zudegefxlieg\"},\"\":{\"zkah\":\"dataosmhssfnw\",\"cufthdgwuzrono\":\"dataecknfm\",\"odcikgxk\":\"datavhzfkdnwy\"}}")
.toObject(AmazonRdsForOracleTableDataset.class);
- Assertions.assertEquals("xxdplrelfkvga", model.description());
- Assertions.assertEquals("ktlhqash", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("ozsxagyso").type());
- Assertions.assertEquals("ykugdla", model.folder().name());
+ Assertions.assertEquals("pchiypbfhmih", model.description());
+ Assertions.assertEquals("jwsreruk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("jy").type());
+ Assertions.assertEquals("zudegefxlieg", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonRdsForOracleTableDataset model = new AmazonRdsForOracleTableDataset().withDescription("xxdplrelfkvga")
- .withStructure("databtuxlbpxrhrfje")
- .withSchema("dataazwef")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ktlhqash")
- .withParameters(mapOf("tacfvvtdpcbp", "datatjixyzsecigzzdw", "brhfiwltkfysunte", "datafomcsau", "whcv",
- "datahkl", "xyxxhwr", "datasyyhgqokjbmsrk")))
- .withParameters(mapOf("ozsxagyso",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqsyilpzzbrwnr"),
- "vrrbnhy", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataiksy"),
- "dyllm", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datahujc")))
- .withAnnotations(Arrays.asList("datastizsyqag", "datallcbrva", "datadylkyhtr", "dataqwfyybptmjjr"))
- .withFolder(new DatasetFolder().withName("ykugdla"))
- .withSchemaTypePropertiesSchema("datawcjomipvw")
- .withTable("dataujttwykoxvbw");
+ AmazonRdsForOracleTableDataset model = new AmazonRdsForOracleTableDataset().withDescription("pchiypbfhmih")
+ .withStructure("datatqozewbrsrjzgkbr")
+ .withSchema("dataxboufqnnqbjx")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("jwsreruk")
+ .withParameters(mapOf("wkjxlaaced", "datadrizw", "lssybzbev", "datakq")))
+ .withParameters(mapOf("jy",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datammkiqhypwtmzy"), "i",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datamzqlnaag")))
+ .withAnnotations(Arrays.asList("datafqiywhxpsb", "datapialezay"))
+ .withFolder(new DatasetFolder().withName("zudegefxlieg"))
+ .withSchemaTypePropertiesSchema("datankfrwxo")
+ .withTable("dataydsn");
model = BinaryData.fromObject(model).toObject(AmazonRdsForOracleTableDataset.class);
- Assertions.assertEquals("xxdplrelfkvga", model.description());
- Assertions.assertEquals("ktlhqash", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("ozsxagyso").type());
- Assertions.assertEquals("ykugdla", model.folder().name());
+ Assertions.assertEquals("pchiypbfhmih", model.description());
+ Assertions.assertEquals("jwsreruk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("jy").type());
+ Assertions.assertEquals("zudegefxlieg", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTypePropertiesTests.java
index 22809186dbfe..091bf4046708 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForOracleTableDatasetTypePropertiesTests.java
@@ -11,15 +11,14 @@ public final class AmazonRdsForOracleTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRdsForOracleTableDatasetTypeProperties model
- = BinaryData.fromString("{\"schema\":\"dataszcfyzqpeqreg\",\"table\":\"datardpagknxmaovr\"}")
+ = BinaryData.fromString("{\"schema\":\"datazfzdjekeb\",\"table\":\"datanxzsjwy\"}")
.toObject(AmazonRdsForOracleTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AmazonRdsForOracleTableDatasetTypeProperties model
- = new AmazonRdsForOracleTableDatasetTypeProperties().withSchema("dataszcfyzqpeqreg")
- .withTable("datardpagknxmaovr");
+ = new AmazonRdsForOracleTableDatasetTypeProperties().withSchema("datazfzdjekeb").withTable("datanxzsjwy");
model = BinaryData.fromObject(model).toObject(AmazonRdsForOracleTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerSourceTests.java
index 37bdd4852606..f4a9bb725ce2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerSourceTests.java
@@ -12,27 +12,27 @@ public final class AmazonRdsForSqlServerSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRdsForSqlServerSource model = BinaryData.fromString(
- "{\"type\":\"AmazonRdsForSqlServerSource\",\"sqlReaderQuery\":\"databsxhivncuela\",\"sqlReaderStoredProcedureName\":\"dataxc\",\"storedProcedureParameters\":\"datartlnzdk\",\"isolationLevel\":\"datafeavz\",\"produceAdditionalTypes\":\"datammzisljxphwy\",\"partitionOption\":\"datamcpfrakucgjreoac\",\"partitionSettings\":{\"partitionColumnName\":\"datab\",\"partitionUpperBound\":\"datazxkdzmtkmnyu\",\"partitionLowerBound\":\"dataemrclsxgpkyetmt\"},\"queryTimeout\":\"dataihixisdvy\",\"additionalColumns\":\"datakeqg\",\"sourceRetryCount\":\"datajsbtosiwcve\",\"sourceRetryWait\":\"dataehbw\",\"maxConcurrentConnections\":\"dataoc\",\"disableMetricsCollection\":\"datazlfhhwdajfth\",\"\":{\"on\":\"datauomj\",\"qsniobehxxb\":\"datafq\"}}")
+ "{\"type\":\"AmazonRdsForSqlServerSource\",\"sqlReaderQuery\":\"dataqfaxtl\",\"sqlReaderStoredProcedureName\":\"datayzcgugslpvy\",\"storedProcedureParameters\":\"datafuhfa\",\"isolationLevel\":\"dataibvslocdkp\",\"produceAdditionalTypes\":\"datakq\",\"partitionOption\":\"datahdxnzjza\",\"partitionSettings\":{\"partitionColumnName\":\"dataiz\",\"partitionUpperBound\":\"datamibwzuhyda\",\"partitionLowerBound\":\"datakgwtbfxxsfj\"},\"queryTimeout\":\"dataascjighmkdsv\",\"additionalColumns\":\"datayhtiyxeh\",\"sourceRetryCount\":\"dataizoybtehky\",\"sourceRetryWait\":\"datanmmyznw\",\"maxConcurrentConnections\":\"datafqwkqulkzovqohwi\",\"disableMetricsCollection\":\"datarqxjxlsso\",\"\":{\"nsjjjcddsv\":\"datanyp\",\"jhpmajg\":\"datadbfniqxbc\",\"jwjhmtca\":\"datazpdioddtjylimz\"}}")
.toObject(AmazonRdsForSqlServerSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonRdsForSqlServerSource model = new AmazonRdsForSqlServerSource().withSourceRetryCount("datajsbtosiwcve")
- .withSourceRetryWait("dataehbw")
- .withMaxConcurrentConnections("dataoc")
- .withDisableMetricsCollection("datazlfhhwdajfth")
- .withQueryTimeout("dataihixisdvy")
- .withAdditionalColumns("datakeqg")
- .withSqlReaderQuery("databsxhivncuela")
- .withSqlReaderStoredProcedureName("dataxc")
- .withStoredProcedureParameters("datartlnzdk")
- .withIsolationLevel("datafeavz")
- .withProduceAdditionalTypes("datammzisljxphwy")
- .withPartitionOption("datamcpfrakucgjreoac")
- .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datab")
- .withPartitionUpperBound("datazxkdzmtkmnyu")
- .withPartitionLowerBound("dataemrclsxgpkyetmt"));
+ AmazonRdsForSqlServerSource model = new AmazonRdsForSqlServerSource().withSourceRetryCount("dataizoybtehky")
+ .withSourceRetryWait("datanmmyznw")
+ .withMaxConcurrentConnections("datafqwkqulkzovqohwi")
+ .withDisableMetricsCollection("datarqxjxlsso")
+ .withQueryTimeout("dataascjighmkdsv")
+ .withAdditionalColumns("datayhtiyxeh")
+ .withSqlReaderQuery("dataqfaxtl")
+ .withSqlReaderStoredProcedureName("datayzcgugslpvy")
+ .withStoredProcedureParameters("datafuhfa")
+ .withIsolationLevel("dataibvslocdkp")
+ .withProduceAdditionalTypes("datakq")
+ .withPartitionOption("datahdxnzjza")
+ .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("dataiz")
+ .withPartitionUpperBound("datamibwzuhyda")
+ .withPartitionLowerBound("datakgwtbfxxsfj"));
model = BinaryData.fromObject(model).toObject(AmazonRdsForSqlServerSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTests.java
index 61c6e12e3892..f1e33c5ff0c2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTests.java
@@ -19,36 +19,38 @@ public final class AmazonRdsForSqlServerTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRdsForSqlServerTableDataset model = BinaryData.fromString(
- "{\"type\":\"AmazonRdsForSqlServerTable\",\"typeProperties\":{\"schema\":\"dataumtcqxmyvkxixypa\",\"table\":\"datafjczgohvpsuwi\"},\"description\":\"m\",\"structure\":\"datazbyfkoc\",\"schema\":\"datazdct\",\"linkedServiceName\":{\"referenceName\":\"nlwsc\",\"parameters\":{\"lks\":\"datatwgxrolwv\"}},\"parameters\":{\"hbvjhxvpmq\":{\"type\":\"Object\",\"defaultValue\":\"dataacuctihavi\"},\"phngr\":{\"type\":\"SecureString\",\"defaultValue\":\"dataux\"},\"icgym\":{\"type\":\"Float\",\"defaultValue\":\"dataxoweorocr\"},\"vhtvijvwmrg\":{\"type\":\"String\",\"defaultValue\":\"dataqpfy\"}},\"annotations\":[\"datahrplcxfmbzquuutq\",\"datahbtqyzy\",\"datag\",\"datambky\"],\"folder\":{\"name\":\"jdqosxzmdzlybqfu\"},\"\":{\"fkicxhsevmnkggh\":\"datak\",\"vbjsarxsvmfp\":\"datasryjokvl\"}}")
+ "{\"type\":\"AmazonRdsForSqlServerTable\",\"typeProperties\":{\"schema\":\"datawvxcimp\",\"table\":\"datajrmplzmsl\"},\"description\":\"nkn\",\"structure\":\"datauysjhvrr\",\"schema\":\"datafswarmybw\",\"linkedServiceName\":{\"referenceName\":\"rotgeysyq\",\"parameters\":{\"xia\":\"dataehfwwcbf\"}},\"parameters\":{\"yzguaxfhvjixg\":{\"type\":\"String\",\"defaultValue\":\"datacfjisosfzlnraxn\"},\"xdoicqpkntly\":{\"type\":\"SecureString\",\"defaultValue\":\"datadqwsjmihuvrqp\"},\"nsbmzjritukoym\":{\"type\":\"Int\",\"defaultValue\":\"datap\"},\"ndu\":{\"type\":\"Int\",\"defaultValue\":\"dataexmizzjxwjoqfzw\"}},\"annotations\":[\"dataw\",\"datavolxtqmricdsflzb\"],\"folder\":{\"name\":\"mjfgoxedrmra\"},\"\":{\"uzsoowxcsm\":\"datachvvoyiogbntnwz\",\"bsp\":\"datatlcappnvc\"}}")
.toObject(AmazonRdsForSqlServerTableDataset.class);
- Assertions.assertEquals("m", model.description());
- Assertions.assertEquals("nlwsc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("hbvjhxvpmq").type());
- Assertions.assertEquals("jdqosxzmdzlybqfu", model.folder().name());
+ Assertions.assertEquals("nkn", model.description());
+ Assertions.assertEquals("rotgeysyq", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("yzguaxfhvjixg").type());
+ Assertions.assertEquals("mjfgoxedrmra", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonRdsForSqlServerTableDataset model = new AmazonRdsForSqlServerTableDataset().withDescription("m")
- .withStructure("datazbyfkoc")
- .withSchema("datazdct")
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("nlwsc").withParameters(mapOf("lks", "datatwgxrolwv")))
- .withParameters(mapOf("hbvjhxvpmq",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataacuctihavi"), "phngr",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataux"), "icgym",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataxoweorocr"),
- "vhtvijvwmrg",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataqpfy")))
- .withAnnotations(Arrays.asList("datahrplcxfmbzquuutq", "datahbtqyzy", "datag", "datambky"))
- .withFolder(new DatasetFolder().withName("jdqosxzmdzlybqfu"))
- .withSchemaTypePropertiesSchema("dataumtcqxmyvkxixypa")
- .withTable("datafjczgohvpsuwi");
+ AmazonRdsForSqlServerTableDataset model = new AmazonRdsForSqlServerTableDataset().withDescription("nkn")
+ .withStructure("datauysjhvrr")
+ .withSchema("datafswarmybw")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rotgeysyq")
+ .withParameters(mapOf("xia", "dataehfwwcbf")))
+ .withParameters(mapOf("yzguaxfhvjixg",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datacfjisosfzlnraxn"),
+ "xdoicqpkntly",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datadqwsjmihuvrqp"),
+ "nsbmzjritukoym", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datap"),
+ "ndu",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataexmizzjxwjoqfzw")))
+ .withAnnotations(Arrays.asList("dataw", "datavolxtqmricdsflzb"))
+ .withFolder(new DatasetFolder().withName("mjfgoxedrmra"))
+ .withSchemaTypePropertiesSchema("datawvxcimp")
+ .withTable("datajrmplzmsl");
model = BinaryData.fromObject(model).toObject(AmazonRdsForSqlServerTableDataset.class);
- Assertions.assertEquals("m", model.description());
- Assertions.assertEquals("nlwsc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("hbvjhxvpmq").type());
- Assertions.assertEquals("jdqosxzmdzlybqfu", model.folder().name());
+ Assertions.assertEquals("nkn", model.description());
+ Assertions.assertEquals("rotgeysyq", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("yzguaxfhvjixg").type());
+ Assertions.assertEquals("mjfgoxedrmra", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTypePropertiesTests.java
index 66a8fe86190d..8150d1f9e37d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRdsForSqlServerTableDatasetTypePropertiesTests.java
@@ -11,14 +11,15 @@ public final class AmazonRdsForSqlServerTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRdsForSqlServerTableDatasetTypeProperties model
- = BinaryData.fromString("{\"schema\":\"datawbpzgfgqp\",\"table\":\"datahgxg\"}")
+ = BinaryData.fromString("{\"schema\":\"dataryomhkdwuwe\",\"table\":\"datapbkmzkwhjjs\"}")
.toObject(AmazonRdsForSqlServerTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AmazonRdsForSqlServerTableDatasetTypeProperties model
- = new AmazonRdsForSqlServerTableDatasetTypeProperties().withSchema("datawbpzgfgqp").withTable("datahgxg");
+ = new AmazonRdsForSqlServerTableDatasetTypeProperties().withSchema("dataryomhkdwuwe")
+ .withTable("datapbkmzkwhjjs");
model = BinaryData.fromObject(model).toObject(AmazonRdsForSqlServerTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftSourceTests.java
index ca992db2c6ff..706de4dfa11b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftSourceTests.java
@@ -16,26 +16,29 @@ public final class AmazonRedshiftSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRedshiftSource model = BinaryData.fromString(
- "{\"type\":\"AmazonRedshiftSource\",\"query\":\"dataqzgy\",\"redshiftUnloadSettings\":{\"s3LinkedServiceName\":{\"referenceName\":\"yy\",\"parameters\":{\"o\":\"datadkjykvez\",\"z\":\"datatzd\",\"r\":\"databmzldplamccql\"}},\"bucketName\":\"dataveqleozqqwiawb\"},\"queryTimeout\":\"datayvbuifhysa\",\"additionalColumns\":\"datapl\",\"sourceRetryCount\":\"dataujsrlzw\",\"sourceRetryWait\":\"datakprf\",\"maxConcurrentConnections\":\"datacowtoqfwbsbkob\",\"disableMetricsCollection\":\"datassj\",\"\":{\"ulswajbhespfgm\":\"datafcxwrjbrxmrsett\",\"gmxqaupypxg\":\"datasiskihfslyipj\",\"yf\":\"dataypokoo\"}}")
+ "{\"type\":\"AmazonRedshiftSource\",\"query\":\"datatgmxkol\",\"redshiftUnloadSettings\":{\"s3LinkedServiceName\":{\"referenceName\":\"nqjcmkpxbckjrfkw\",\"parameters\":{\"zatqocvrdj\":\"datamyowddhtwaxob\",\"cyvymv\":\"datavsclwpsteuvjdnh\",\"omohcynorh\":\"datalaehitxoib\",\"f\":\"databvbqxtktkeuapomo\"}},\"bucketName\":\"datanbhptraljcqp\"},\"queryTimeout\":\"datamathiydmkyvsxc\",\"additionalColumns\":\"datavghajpddgfoznmf\",\"sourceRetryCount\":\"datapjoesozcuhun\",\"sourceRetryWait\":\"datazbmwptdr\",\"maxConcurrentConnections\":\"datauyknoiumuxn\",\"disableMetricsCollection\":\"dataivgmck\",\"\":{\"oj\":\"dataxzsmpoiutaatvpb\",\"kekmgpseassdqpw\":\"datacgjogmvo\",\"pwxcjciotlbp\":\"datapxwdosfgbvsozjf\"}}")
.toObject(AmazonRedshiftSource.class);
- Assertions.assertEquals("yy", model.redshiftUnloadSettings().s3LinkedServiceName().referenceName());
+ Assertions.assertEquals("nqjcmkpxbckjrfkw",
+ model.redshiftUnloadSettings().s3LinkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonRedshiftSource model = new AmazonRedshiftSource().withSourceRetryCount("dataujsrlzw")
- .withSourceRetryWait("datakprf")
- .withMaxConcurrentConnections("datacowtoqfwbsbkob")
- .withDisableMetricsCollection("datassj")
- .withQueryTimeout("datayvbuifhysa")
- .withAdditionalColumns("datapl")
- .withQuery("dataqzgy")
+ AmazonRedshiftSource model = new AmazonRedshiftSource().withSourceRetryCount("datapjoesozcuhun")
+ .withSourceRetryWait("datazbmwptdr")
+ .withMaxConcurrentConnections("datauyknoiumuxn")
+ .withDisableMetricsCollection("dataivgmck")
+ .withQueryTimeout("datamathiydmkyvsxc")
+ .withAdditionalColumns("datavghajpddgfoznmf")
+ .withQuery("datatgmxkol")
.withRedshiftUnloadSettings(new RedshiftUnloadSettings()
- .withS3LinkedServiceName(new LinkedServiceReference().withReferenceName("yy")
- .withParameters(mapOf("o", "datadkjykvez", "z", "datatzd", "r", "databmzldplamccql")))
- .withBucketName("dataveqleozqqwiawb"));
+ .withS3LinkedServiceName(new LinkedServiceReference().withReferenceName("nqjcmkpxbckjrfkw")
+ .withParameters(mapOf("zatqocvrdj", "datamyowddhtwaxob", "cyvymv", "datavsclwpsteuvjdnh",
+ "omohcynorh", "datalaehitxoib", "f", "databvbqxtktkeuapomo")))
+ .withBucketName("datanbhptraljcqp"));
model = BinaryData.fromObject(model).toObject(AmazonRedshiftSource.class);
- Assertions.assertEquals("yy", model.redshiftUnloadSettings().s3LinkedServiceName().referenceName());
+ Assertions.assertEquals("nqjcmkpxbckjrfkw",
+ model.redshiftUnloadSettings().s3LinkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTests.java
index 53fa2ac40ed3..38ab8aba78ec 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTests.java
@@ -19,39 +19,37 @@ public final class AmazonRedshiftTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonRedshiftTableDataset model = BinaryData.fromString(
- "{\"type\":\"AmazonRedshiftTable\",\"typeProperties\":{\"tableName\":\"dataonmzrjjaojpzn\",\"table\":\"datarz\",\"schema\":\"dataecwsadsqyuddkh\"},\"description\":\"dmohheuyu\",\"structure\":\"dataxmyevyigdeipnfi\",\"schema\":\"datajwlii\",\"linkedServiceName\":{\"referenceName\":\"cndjzwhajo\",\"parameters\":{\"w\":\"dataqokhdyncradxs\",\"pfapmqnmelyk\":\"datae\",\"kqvzlbbbajdexq\":\"dataygihiclmslnu\"}},\"parameters\":{\"etji\":{\"type\":\"Bool\",\"defaultValue\":\"dataizbf\"},\"v\":{\"type\":\"Array\",\"defaultValue\":\"datapnbmajvvyxt\"},\"ybfmlngfwhrmvl\":{\"type\":\"SecureString\",\"defaultValue\":\"datakzixbk\"},\"hsmfndcbsyhludzj\":{\"type\":\"Bool\",\"defaultValue\":\"dataujmwxnrzblxna\"}},\"annotations\":[\"datavohwvprjf\"],\"folder\":{\"name\":\"durmdtacn\"},\"\":{\"skkfkuyikm\":\"dataaffhvqiiasbt\",\"qtrefe\":\"datahhqsxjbjkewrigl\",\"cjffzwn\":\"datalfl\",\"onztpcjptnnt\":\"datavdef\"}}")
+ "{\"type\":\"AmazonRedshiftTable\",\"typeProperties\":{\"tableName\":\"datargyzcslazp\",\"table\":\"dataqoyimxp\",\"schema\":\"dataktteagbga\"},\"description\":\"qpjuytvude\",\"structure\":\"datapbybkisboif\",\"schema\":\"dataglpwdjr\",\"linkedServiceName\":{\"referenceName\":\"urfshzn\",\"parameters\":{\"txfrm\":\"datatuhaaaxxdcdjmdk\",\"ehxuihwes\":\"dataecxstowa\"}},\"parameters\":{\"tevspsaneyvaerp\":{\"type\":\"String\",\"defaultValue\":\"datagblkkncyp\"},\"kjwqdmraqnilp\":{\"type\":\"String\",\"defaultValue\":\"datanhrfbrj\"},\"lrfdjwlzseod\":{\"type\":\"Bool\",\"defaultValue\":\"dataaigazwf\"}},\"annotations\":[\"datadr\",\"datal\",\"dataymqxserwy\"],\"folder\":{\"name\":\"ytjwgetfigw\"},\"\":{\"ebjrahgdstubwg\":\"datajxzi\",\"mdoiiyobqzwjal\":\"dataxzsshxliqmsckwh\"}}")
.toObject(AmazonRedshiftTableDataset.class);
- Assertions.assertEquals("dmohheuyu", model.description());
- Assertions.assertEquals("cndjzwhajo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("etji").type());
- Assertions.assertEquals("durmdtacn", model.folder().name());
+ Assertions.assertEquals("qpjuytvude", model.description());
+ Assertions.assertEquals("urfshzn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("tevspsaneyvaerp").type());
+ Assertions.assertEquals("ytjwgetfigw", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonRedshiftTableDataset model = new AmazonRedshiftTableDataset().withDescription("dmohheuyu")
- .withStructure("dataxmyevyigdeipnfi")
- .withSchema("datajwlii")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("cndjzwhajo")
- .withParameters(
- mapOf("w", "dataqokhdyncradxs", "pfapmqnmelyk", "datae", "kqvzlbbbajdexq", "dataygihiclmslnu")))
- .withParameters(
- mapOf("etji", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataizbf"),
- "v", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datapnbmajvvyxt"),
- "ybfmlngfwhrmvl",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datakzixbk"),
- "hsmfndcbsyhludzj",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataujmwxnrzblxna")))
- .withAnnotations(Arrays.asList("datavohwvprjf"))
- .withFolder(new DatasetFolder().withName("durmdtacn"))
- .withTableName("dataonmzrjjaojpzn")
- .withTable("datarz")
- .withSchemaTypePropertiesSchema("dataecwsadsqyuddkh");
+ AmazonRedshiftTableDataset model = new AmazonRedshiftTableDataset().withDescription("qpjuytvude")
+ .withStructure("datapbybkisboif")
+ .withSchema("dataglpwdjr")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("urfshzn")
+ .withParameters(mapOf("txfrm", "datatuhaaaxxdcdjmdk", "ehxuihwes", "dataecxstowa")))
+ .withParameters(mapOf("tevspsaneyvaerp",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datagblkkncyp"),
+ "kjwqdmraqnilp",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datanhrfbrj"),
+ "lrfdjwlzseod",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataaigazwf")))
+ .withAnnotations(Arrays.asList("datadr", "datal", "dataymqxserwy"))
+ .withFolder(new DatasetFolder().withName("ytjwgetfigw"))
+ .withTableName("datargyzcslazp")
+ .withTable("dataqoyimxp")
+ .withSchemaTypePropertiesSchema("dataktteagbga");
model = BinaryData.fromObject(model).toObject(AmazonRedshiftTableDataset.class);
- Assertions.assertEquals("dmohheuyu", model.description());
- Assertions.assertEquals("cndjzwhajo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("etji").type());
- Assertions.assertEquals("durmdtacn", model.folder().name());
+ Assertions.assertEquals("qpjuytvude", model.description());
+ Assertions.assertEquals("urfshzn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("tevspsaneyvaerp").type());
+ Assertions.assertEquals("ytjwgetfigw", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTypePropertiesTests.java
index 8d4b85c20317..3d914429733e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonRedshiftTableDatasetTypePropertiesTests.java
@@ -10,17 +10,17 @@
public final class AmazonRedshiftTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- AmazonRedshiftTableDatasetTypeProperties model = BinaryData.fromString(
- "{\"tableName\":\"datacjqpzjvnpjr\",\"table\":\"datapgsjbioagwviqehm\",\"schema\":\"datavaolidxdfsfvkjc\"}")
+ AmazonRedshiftTableDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"datasofxc\",\"table\":\"datarmvjfmrsuyd\",\"schema\":\"dataprel\"}")
.toObject(AmazonRedshiftTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AmazonRedshiftTableDatasetTypeProperties model
- = new AmazonRedshiftTableDatasetTypeProperties().withTableName("datacjqpzjvnpjr")
- .withTable("datapgsjbioagwviqehm")
- .withSchema("datavaolidxdfsfvkjc");
+ = new AmazonRedshiftTableDatasetTypeProperties().withTableName("datasofxc")
+ .withTable("datarmvjfmrsuyd")
+ .withSchema("dataprel");
model = BinaryData.fromObject(model).toObject(AmazonRedshiftTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3CompatibleReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3CompatibleReadSettingsTests.java
index a4f8a64166c0..50fa3e6c1867 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3CompatibleReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3CompatibleReadSettingsTests.java
@@ -11,25 +11,25 @@ public final class AmazonS3CompatibleReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonS3CompatibleReadSettings model = BinaryData.fromString(
- "{\"type\":\"AmazonS3CompatibleReadSettings\",\"recursive\":\"datau\",\"wildcardFolderPath\":\"datarbjxewcscuveljf\",\"wildcardFileName\":\"datain\",\"prefix\":\"dataziztgddahymv\",\"fileListPath\":\"datajtdhmig\",\"enablePartitionDiscovery\":\"dataaoexgienylsijqyg\",\"partitionRootPath\":\"datashd\",\"deleteFilesAfterCompletion\":\"datahxv\",\"modifiedDatetimeStart\":\"datafdsafgkysymhuxs\",\"modifiedDatetimeEnd\":\"datallbpegcetezaa\",\"maxConcurrentConnections\":\"dataszrbttz\",\"disableMetricsCollection\":\"dataeyrw\",\"\":{\"ecurf\":\"datagoyxxszpa\",\"giixu\":\"dataofshf\",\"ywoefkpuuu\":\"dataveekhsmulv\",\"fipygt\":\"dataiuwhcyckekm\"}}")
+ "{\"type\":\"AmazonS3CompatibleReadSettings\",\"recursive\":\"datayglfyfcsbkjhoxtb\",\"wildcardFolderPath\":\"databpef\",\"wildcardFileName\":\"datapnixdgqjkfvmrn\",\"prefix\":\"dataeajyifeiiriomjd\",\"fileListPath\":\"datanbtlxrdepqt\",\"enablePartitionDiscovery\":\"datahkpko\",\"partitionRootPath\":\"datavfno\",\"deleteFilesAfterCompletion\":\"datawhutvcdtgxsyfuh\",\"modifiedDatetimeStart\":\"datamzxpsrlbppjqcwc\",\"modifiedDatetimeEnd\":\"dataaosk\",\"maxConcurrentConnections\":\"dataalljsoasxjjklm\",\"disableMetricsCollection\":\"datagrosxfdxrc\",\"\":{\"zlreiwdskiegta\":\"databbhluvdceouevno\",\"ptaasqolxaodb\":\"datanal\",\"mihggvyhqwyxb\":\"datagxbadborq\"}}")
.toObject(AmazonS3CompatibleReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AmazonS3CompatibleReadSettings model
- = new AmazonS3CompatibleReadSettings().withMaxConcurrentConnections("dataszrbttz")
- .withDisableMetricsCollection("dataeyrw")
- .withRecursive("datau")
- .withWildcardFolderPath("datarbjxewcscuveljf")
- .withWildcardFileName("datain")
- .withPrefix("dataziztgddahymv")
- .withFileListPath("datajtdhmig")
- .withEnablePartitionDiscovery("dataaoexgienylsijqyg")
- .withPartitionRootPath("datashd")
- .withDeleteFilesAfterCompletion("datahxv")
- .withModifiedDatetimeStart("datafdsafgkysymhuxs")
- .withModifiedDatetimeEnd("datallbpegcetezaa");
+ = new AmazonS3CompatibleReadSettings().withMaxConcurrentConnections("dataalljsoasxjjklm")
+ .withDisableMetricsCollection("datagrosxfdxrc")
+ .withRecursive("datayglfyfcsbkjhoxtb")
+ .withWildcardFolderPath("databpef")
+ .withWildcardFileName("datapnixdgqjkfvmrn")
+ .withPrefix("dataeajyifeiiriomjd")
+ .withFileListPath("datanbtlxrdepqt")
+ .withEnablePartitionDiscovery("datahkpko")
+ .withPartitionRootPath("datavfno")
+ .withDeleteFilesAfterCompletion("datawhutvcdtgxsyfuh")
+ .withModifiedDatetimeStart("datamzxpsrlbppjqcwc")
+ .withModifiedDatetimeEnd("dataaosk");
model = BinaryData.fromObject(model).toObject(AmazonS3CompatibleReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3ReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3ReadSettingsTests.java
index 1e19eb7852e7..056628ec9919 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3ReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AmazonS3ReadSettingsTests.java
@@ -11,24 +11,24 @@ public final class AmazonS3ReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AmazonS3ReadSettings model = BinaryData.fromString(
- "{\"type\":\"AmazonS3ReadSettings\",\"recursive\":\"datayliagnbhzte\",\"wildcardFolderPath\":\"datanafy\",\"wildcardFileName\":\"dataaocvetzk\",\"prefix\":\"datalbclspqvxz\",\"fileListPath\":\"datau\",\"enablePartitionDiscovery\":\"datafngpbvdlkpzdki\",\"partitionRootPath\":\"datawenvxuhzixranb\",\"deleteFilesAfterCompletion\":\"dataejfqghgadrvxbcy\",\"modifiedDatetimeStart\":\"dataajbcbrtiqpjlakam\",\"modifiedDatetimeEnd\":\"dataqluicrqxqjzmosml\",\"maxConcurrentConnections\":\"datappfgtnsxdj\",\"disableMetricsCollection\":\"datatnjpkpmdlttmfhde\",\"\":{\"xpebsxcnhq\":\"dataaaiqyxlro\",\"rdamyumr\":\"datacbtyor\",\"ygj\":\"databbaxnym\",\"qznobsdgyheyayk\":\"dataqmkakgw\"}}")
+ "{\"type\":\"AmazonS3ReadSettings\",\"recursive\":\"dataziztgddahymv\",\"wildcardFolderPath\":\"datajtdhmig\",\"wildcardFileName\":\"dataaoexgienylsijqyg\",\"prefix\":\"datashd\",\"fileListPath\":\"datahxv\",\"enablePartitionDiscovery\":\"datafdsafgkysymhuxs\",\"partitionRootPath\":\"datallbpegcetezaa\",\"deleteFilesAfterCompletion\":\"dataszrbttz\",\"modifiedDatetimeStart\":\"dataeyrw\",\"modifiedDatetimeEnd\":\"datafgoyxxszpaiecurf\",\"maxConcurrentConnections\":\"datafshfmgiixurve\",\"disableMetricsCollection\":\"datahsmulvmy\",\"\":{\"mufipygtmoycpotm\":\"datafkpuuuxiuwhcycke\",\"ngtbhvhsqvubww\":\"dataos\"}}")
.toObject(AmazonS3ReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AmazonS3ReadSettings model = new AmazonS3ReadSettings().withMaxConcurrentConnections("datappfgtnsxdj")
- .withDisableMetricsCollection("datatnjpkpmdlttmfhde")
- .withRecursive("datayliagnbhzte")
- .withWildcardFolderPath("datanafy")
- .withWildcardFileName("dataaocvetzk")
- .withPrefix("datalbclspqvxz")
- .withFileListPath("datau")
- .withEnablePartitionDiscovery("datafngpbvdlkpzdki")
- .withPartitionRootPath("datawenvxuhzixranb")
- .withDeleteFilesAfterCompletion("dataejfqghgadrvxbcy")
- .withModifiedDatetimeStart("dataajbcbrtiqpjlakam")
- .withModifiedDatetimeEnd("dataqluicrqxqjzmosml");
+ AmazonS3ReadSettings model = new AmazonS3ReadSettings().withMaxConcurrentConnections("datafshfmgiixurve")
+ .withDisableMetricsCollection("datahsmulvmy")
+ .withRecursive("dataziztgddahymv")
+ .withWildcardFolderPath("datajtdhmig")
+ .withWildcardFileName("dataaoexgienylsijqyg")
+ .withPrefix("datashd")
+ .withFileListPath("datahxv")
+ .withEnablePartitionDiscovery("datafdsafgkysymhuxs")
+ .withPartitionRootPath("datallbpegcetezaa")
+ .withDeleteFilesAfterCompletion("dataszrbttz")
+ .withModifiedDatetimeStart("dataeyrw")
+ .withModifiedDatetimeEnd("datafgoyxxszpaiecurf");
model = BinaryData.fromObject(model).toObject(AmazonS3ReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTests.java
index 7dfa44bfd43b..9703d260d086 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTests.java
@@ -20,42 +20,46 @@ public final class AppendVariableActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AppendVariableActivity model = BinaryData.fromString(
- "{\"type\":\"AppendVariable\",\"typeProperties\":{\"variableName\":\"lgwpu\",\"value\":\"databfcblvakh\"},\"name\":\"igxxtfvoa\",\"description\":\"hdiiwv\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"mqartpdy\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Completed\",\"Failed\"],\"\":{\"jcow\":\"dataxpmtztvxfglil\",\"rt\":\"datazqyocjxs\"}}],\"userProperties\":[{\"name\":\"aampgenyvpx\",\"value\":\"datacjn\"},{\"name\":\"nffexzzijt\",\"value\":\"datat\"},{\"name\":\"ewniwt\",\"value\":\"dataplwyluvqp\"}],\"\":{\"qsnttwlxvezoald\":\"datao\",\"miccgubuivzs\":\"datasesxcqtosoanxin\"}}")
+ "{\"type\":\"AppendVariable\",\"typeProperties\":{\"variableName\":\"q\",\"value\":\"dataf\"},\"name\":\"gntrynfoaoeuztps\",\"description\":\"hdqcrigygtodp\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"bybrvkxrcfzsz\",\"dependencyConditions\":[\"Succeeded\",\"Completed\"],\"\":{\"uuzftd\":\"dataucvq\",\"vxtz\":\"dataktmsphcrn\",\"pigsulejukack\":\"dataspykcreu\"}},{\"activity\":\"crdrdkexcyw\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Completed\",\"Succeeded\"],\"\":{\"rsajtdzpel\":\"datajllypchqhc\",\"gczxicqyvwzxqmve\":\"dataktkimm\",\"mrqdgyttfzoz\":\"datatnro\"}}],\"userProperties\":[{\"name\":\"njjimfcgbdup\",\"value\":\"datalwlhuuezxcpxwq\"}],\"\":{\"foosiplhygpsahu\":\"dataqueqeabe\",\"geym\":\"datammshfh\",\"lpnrjswr\":\"datapvgatzr\"}}")
.toObject(AppendVariableActivity.class);
- Assertions.assertEquals("igxxtfvoa", model.name());
- Assertions.assertEquals("hdiiwv", model.description());
+ Assertions.assertEquals("gntrynfoaoeuztps", model.name());
+ Assertions.assertEquals("hdqcrigygtodp", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("mqartpdy", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("aampgenyvpx", model.userProperties().get(0).name());
- Assertions.assertEquals("lgwpu", model.variableName());
+ Assertions.assertEquals("bybrvkxrcfzsz", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("njjimfcgbdup", model.userProperties().get(0).name());
+ Assertions.assertEquals("q", model.variableName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AppendVariableActivity model = new AppendVariableActivity().withName("igxxtfvoa")
- .withDescription("hdiiwv")
+ AppendVariableActivity model = new AppendVariableActivity().withName("gntrynfoaoeuztps")
+ .withDescription("hdqcrigygtodp")
.withState(ActivityState.ACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("mqartpdy")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("aampgenyvpx").withValue("datacjn"),
- new UserProperty().withName("nffexzzijt").withValue("datat"),
- new UserProperty().withName("ewniwt").withValue("dataplwyluvqp")))
- .withVariableName("lgwpu")
- .withValue("databfcblvakh");
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("bybrvkxrcfzsz")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("crdrdkexcyw")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("njjimfcgbdup").withValue("datalwlhuuezxcpxwq")))
+ .withVariableName("q")
+ .withValue("dataf");
model = BinaryData.fromObject(model).toObject(AppendVariableActivity.class);
- Assertions.assertEquals("igxxtfvoa", model.name());
- Assertions.assertEquals("hdiiwv", model.description());
+ Assertions.assertEquals("gntrynfoaoeuztps", model.name());
+ Assertions.assertEquals("hdqcrigygtodp", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("mqartpdy", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("aampgenyvpx", model.userProperties().get(0).name());
- Assertions.assertEquals("lgwpu", model.variableName());
+ Assertions.assertEquals("bybrvkxrcfzsz", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("njjimfcgbdup", model.userProperties().get(0).name());
+ Assertions.assertEquals("q", model.variableName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTypePropertiesTests.java
index 4207d8f04b5f..82279312dd8d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AppendVariableActivityTypePropertiesTests.java
@@ -12,16 +12,16 @@ public final class AppendVariableActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AppendVariableActivityTypeProperties model
- = BinaryData.fromString("{\"variableName\":\"xnenhyhd\",\"value\":\"dataayk\"}")
+ = BinaryData.fromString("{\"variableName\":\"xrecwdle\",\"value\":\"datamuqmzxrjvh\"}")
.toObject(AppendVariableActivityTypeProperties.class);
- Assertions.assertEquals("xnenhyhd", model.variableName());
+ Assertions.assertEquals("xrecwdle", model.variableName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AppendVariableActivityTypeProperties model
- = new AppendVariableActivityTypeProperties().withVariableName("xnenhyhd").withValue("dataayk");
+ = new AppendVariableActivityTypeProperties().withVariableName("xrecwdle").withValue("datamuqmzxrjvh");
model = BinaryData.fromObject(model).toObject(AppendVariableActivityTypeProperties.class);
- Assertions.assertEquals("xnenhyhd", model.variableName());
+ Assertions.assertEquals("xrecwdle", model.variableName());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSinkTests.java
index 6f528959e4db..d882d719055d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSinkTests.java
@@ -18,33 +18,32 @@ public final class AvroSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AvroSink model = BinaryData.fromString(
- "{\"type\":\"AvroSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datayxdigkggzm\",\"disableMetricsCollection\":\"dataqhqeosxdsxi\",\"copyBehavior\":\"datafiottdawgkaohh\",\"metadata\":[{\"name\":\"datahypidzjjjfcyskpn\",\"value\":\"dataxoic\"},{\"name\":\"datasmfvltbocqhv\",\"value\":\"datam\"}],\"\":{\"rcl\":\"datavgrigjegrlgkoqb\",\"uvybe\":\"datarrtfmf\"}},\"formatSettings\":{\"type\":\"AvroWriteSettings\",\"recordName\":\"amshqvku\",\"recordNamespace\":\"zvzqhvzjdsn\",\"maxRowsPerFile\":\"datadbeanigozjrcx\",\"fileNamePrefix\":\"dataugjalmzpfyl\",\"\":{\"dxcizropzgjle\":\"datawwvzn\",\"bhqkvbins\":\"datacf\"}},\"writeBatchSize\":\"dataw\",\"writeBatchTimeout\":\"dataegoupdqeflvd\",\"sinkRetryCount\":\"dataqcqlexobeekzy\",\"sinkRetryWait\":\"datapatwbbf\",\"maxConcurrentConnections\":\"dataflhnwohlc\",\"disableMetricsCollection\":\"datahfuydgdhitavga\",\"\":{\"zeebdefepwkhr\":\"datapzlcvibpd\",\"qvnlhsxea\":\"datazzwgbbozivfo\",\"km\":\"dataxsqquvvscb\",\"ibwuzvmorsyi\":\"datahdukprq\"}}")
+ "{\"type\":\"AvroSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datafsol\",\"disableMetricsCollection\":\"dataquulnhxrcjs\",\"copyBehavior\":\"datacvrmwbg\",\"metadata\":[{\"name\":\"dataqbxp\",\"value\":\"datapgsr\"}],\"\":{\"gspboaevtxibroo\":\"datak\"}},\"formatSettings\":{\"type\":\"AvroWriteSettings\",\"recordName\":\"jiqwxwpub\",\"recordNamespace\":\"qnprbvruhdjzivl\",\"maxRowsPerFile\":\"datai\",\"fileNamePrefix\":\"dataqnqmbf\",\"\":{\"kkzulmqx\":\"dataixmksxxbdtjvvngn\",\"nwij\":\"dataic\",\"er\":\"dataeyxt\",\"ytten\":\"datattobosjxb\"}},\"writeBatchSize\":\"dataditumyycvtya\",\"writeBatchTimeout\":\"datayimhspjqhi\",\"sinkRetryCount\":\"datablqvwhjgtbh\",\"sinkRetryWait\":\"dataoutq\",\"maxConcurrentConnections\":\"datapbtqibq\",\"disableMetricsCollection\":\"dataugcwzgdfdrdxo\",\"\":{\"lxoljbpoeoyw\":\"datagezulnntpbarejxj\",\"rx\":\"datakhhavwhrivvzrccy\",\"bbxanev\":\"datasypwudeea\",\"ju\":\"dataq\"}}")
.toObject(AvroSink.class);
- Assertions.assertEquals("amshqvku", model.formatSettings().recordName());
- Assertions.assertEquals("zvzqhvzjdsn", model.formatSettings().recordNamespace());
+ Assertions.assertEquals("jiqwxwpub", model.formatSettings().recordName());
+ Assertions.assertEquals("qnprbvruhdjzivl", model.formatSettings().recordNamespace());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AvroSink model = new AvroSink().withWriteBatchSize("dataw")
- .withWriteBatchTimeout("dataegoupdqeflvd")
- .withSinkRetryCount("dataqcqlexobeekzy")
- .withSinkRetryWait("datapatwbbf")
- .withMaxConcurrentConnections("dataflhnwohlc")
- .withDisableMetricsCollection("datahfuydgdhitavga")
- .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datayxdigkggzm")
- .withDisableMetricsCollection("dataqhqeosxdsxi")
- .withCopyBehavior("datafiottdawgkaohh")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datahypidzjjjfcyskpn").withValue("dataxoic"),
- new MetadataItem().withName("datasmfvltbocqhv").withValue("datam")))
+ AvroSink model = new AvroSink().withWriteBatchSize("dataditumyycvtya")
+ .withWriteBatchTimeout("datayimhspjqhi")
+ .withSinkRetryCount("datablqvwhjgtbh")
+ .withSinkRetryWait("dataoutq")
+ .withMaxConcurrentConnections("datapbtqibq")
+ .withDisableMetricsCollection("dataugcwzgdfdrdxo")
+ .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datafsol")
+ .withDisableMetricsCollection("dataquulnhxrcjs")
+ .withCopyBehavior("datacvrmwbg")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("dataqbxp").withValue("datapgsr")))
.withAdditionalProperties(mapOf("type", "StoreWriteSettings")))
- .withFormatSettings(new AvroWriteSettings().withRecordName("amshqvku")
- .withRecordNamespace("zvzqhvzjdsn")
- .withMaxRowsPerFile("datadbeanigozjrcx")
- .withFileNamePrefix("dataugjalmzpfyl"));
+ .withFormatSettings(new AvroWriteSettings().withRecordName("jiqwxwpub")
+ .withRecordNamespace("qnprbvruhdjzivl")
+ .withMaxRowsPerFile("datai")
+ .withFileNamePrefix("dataqnqmbf"));
model = BinaryData.fromObject(model).toObject(AvroSink.class);
- Assertions.assertEquals("amshqvku", model.formatSettings().recordName());
- Assertions.assertEquals("zvzqhvzjdsn", model.formatSettings().recordNamespace());
+ Assertions.assertEquals("jiqwxwpub", model.formatSettings().recordName());
+ Assertions.assertEquals("qnprbvruhdjzivl", model.formatSettings().recordNamespace());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSourceTests.java
index b46c4e0c9fdc..dcff4cc0ded3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroSourceTests.java
@@ -14,20 +14,20 @@ public final class AvroSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AvroSource model = BinaryData.fromString(
- "{\"type\":\"AvroSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datariyhdbbj\",\"disableMetricsCollection\":\"datajmcybrpwjenbxtk\",\"\":{\"yxnhu\":\"datarxauuhdkhkizyx\"}},\"additionalColumns\":\"datawip\",\"sourceRetryCount\":\"datayivpezzyrpdx\",\"sourceRetryWait\":\"datafpqxse\",\"maxConcurrentConnections\":\"datazkpdmmowftfrqeb\",\"disableMetricsCollection\":\"dataop\",\"\":{\"rdsdkvhuiadyh\":\"datafekfxmgjywwid\",\"dokuqnkoskf\":\"datadisypgapfdwhwbe\",\"rjee\":\"datanjay\",\"m\":\"datambh\"}}")
+ "{\"type\":\"AvroSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datayylekubiwv\",\"disableMetricsCollection\":\"datazzny\",\"\":{\"isloquttkbzwgju\":\"datawxpwjv\",\"jttnurkmerqzap\":\"datajbdqmnkiajqsshup\",\"jwdlduvimgtce\":\"datawomevqvv\"}},\"additionalColumns\":\"datamxoxtapaf\",\"sourceRetryCount\":\"datavbkjtgzkcptav\",\"sourceRetryWait\":\"datapydnujgblski\",\"maxConcurrentConnections\":\"datarvpuacajxdr\",\"disableMetricsCollection\":\"datapuxpzslm\",\"\":{\"fge\":\"datapzrycchqz\",\"ch\":\"datadzgszjhekbmd\",\"vwysbme\":\"dataojsrhgpitye\",\"bznl\":\"dataf\"}}")
.toObject(AvroSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AvroSource model = new AvroSource().withSourceRetryCount("datayivpezzyrpdx")
- .withSourceRetryWait("datafpqxse")
- .withMaxConcurrentConnections("datazkpdmmowftfrqeb")
- .withDisableMetricsCollection("dataop")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datariyhdbbj")
- .withDisableMetricsCollection("datajmcybrpwjenbxtk")
+ AvroSource model = new AvroSource().withSourceRetryCount("datavbkjtgzkcptav")
+ .withSourceRetryWait("datapydnujgblski")
+ .withMaxConcurrentConnections("datarvpuacajxdr")
+ .withDisableMetricsCollection("datapuxpzslm")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datayylekubiwv")
+ .withDisableMetricsCollection("datazzny")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
- .withAdditionalColumns("datawip");
+ .withAdditionalColumns("datamxoxtapaf");
model = BinaryData.fromObject(model).toObject(AvroSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroWriteSettingsTests.java
index 00c92a903120..30cb3fadffdf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AvroWriteSettingsTests.java
@@ -12,20 +12,20 @@ public final class AvroWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AvroWriteSettings model = BinaryData.fromString(
- "{\"type\":\"AvroWriteSettings\",\"recordName\":\"jxwwqz\",\"recordNamespace\":\"etbffrhqzvwznwc\",\"maxRowsPerFile\":\"dataapd\",\"fileNamePrefix\":\"datakltetfd\",\"\":{\"aafkvqhbw\":\"datavzdtjbesfumed\",\"szsveguxaxijp\":\"datavivqkyaghfvub\"}}")
+ "{\"type\":\"AvroWriteSettings\",\"recordName\":\"ieeoc\",\"recordNamespace\":\"rvsfzgcsco\",\"maxRowsPerFile\":\"datafsgilwisqxzpz\",\"fileNamePrefix\":\"dataustrtrfvogk\",\"\":{\"irbrvz\":\"datashmpcjqtuz\"}}")
.toObject(AvroWriteSettings.class);
- Assertions.assertEquals("jxwwqz", model.recordName());
- Assertions.assertEquals("etbffrhqzvwznwc", model.recordNamespace());
+ Assertions.assertEquals("ieeoc", model.recordName());
+ Assertions.assertEquals("rvsfzgcsco", model.recordNamespace());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AvroWriteSettings model = new AvroWriteSettings().withRecordName("jxwwqz")
- .withRecordNamespace("etbffrhqzvwznwc")
- .withMaxRowsPerFile("dataapd")
- .withFileNamePrefix("datakltetfd");
+ AvroWriteSettings model = new AvroWriteSettings().withRecordName("ieeoc")
+ .withRecordNamespace("rvsfzgcsco")
+ .withMaxRowsPerFile("datafsgilwisqxzpz")
+ .withFileNamePrefix("dataustrtrfvogk");
model = BinaryData.fromObject(model).toObject(AvroWriteSettings.class);
- Assertions.assertEquals("jxwwqz", model.recordName());
- Assertions.assertEquals("etbffrhqzvwznwc", model.recordNamespace());
+ Assertions.assertEquals("ieeoc", model.recordName());
+ Assertions.assertEquals("rvsfzgcsco", model.recordNamespace());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTests.java
index df058f26996c..6e95a4524fed 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTests.java
@@ -12,15 +12,15 @@ public final class AzPowerShellSetupTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzPowerShellSetup model = BinaryData
- .fromString("{\"type\":\"AzPowerShellSetup\",\"typeProperties\":{\"version\":\"cxbbjbeyqohvi\"}}")
+ .fromString("{\"type\":\"AzPowerShellSetup\",\"typeProperties\":{\"version\":\"gjjioqwuuogdkp\"}}")
.toObject(AzPowerShellSetup.class);
- Assertions.assertEquals("cxbbjbeyqohvi", model.version());
+ Assertions.assertEquals("gjjioqwuuogdkp", model.version());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzPowerShellSetup model = new AzPowerShellSetup().withVersion("cxbbjbeyqohvi");
+ AzPowerShellSetup model = new AzPowerShellSetup().withVersion("gjjioqwuuogdkp");
model = BinaryData.fromObject(model).toObject(AzPowerShellSetup.class);
- Assertions.assertEquals("cxbbjbeyqohvi", model.version());
+ Assertions.assertEquals("gjjioqwuuogdkp", model.version());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTypePropertiesTests.java
index 36afcf655b6f..adf568b00b97 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzPowerShellSetupTypePropertiesTests.java
@@ -12,14 +12,14 @@ public final class AzPowerShellSetupTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzPowerShellSetupTypeProperties model
- = BinaryData.fromString("{\"version\":\"wpjfkra\"}").toObject(AzPowerShellSetupTypeProperties.class);
- Assertions.assertEquals("wpjfkra", model.version());
+ = BinaryData.fromString("{\"version\":\"mwr\"}").toObject(AzPowerShellSetupTypeProperties.class);
+ Assertions.assertEquals("mwr", model.version());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzPowerShellSetupTypeProperties model = new AzPowerShellSetupTypeProperties().withVersion("wpjfkra");
+ AzPowerShellSetupTypeProperties model = new AzPowerShellSetupTypeProperties().withVersion("mwr");
model = BinaryData.fromObject(model).toObject(AzPowerShellSetupTypeProperties.class);
- Assertions.assertEquals("wpjfkra", model.version());
+ Assertions.assertEquals("mwr", model.version());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTests.java
index 783f3b046a5b..706eb466c964 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTests.java
@@ -21,43 +21,40 @@ public final class AzureBlobDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobDataset model = BinaryData.fromString(
- "{\"type\":\"AzureBlob\",\"typeProperties\":{\"folderPath\":\"dataufpnezsjzaymld\",\"tableRootLocation\":\"datar\",\"fileName\":\"dataogzmsimehtcuuwdh\",\"modifiedDatetimeStart\":\"dataqhyhni\",\"modifiedDatetimeEnd\":\"datatnsugisno\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datawnghojo\",\"deserializer\":\"dataeyym\",\"\":{\"nuguefxx\":\"dataixxfsfpcr\",\"bdveywetkrhl\":\"datajt\",\"bv\":\"datalmcnwepfgsv\"}},\"compression\":{\"type\":\"datadljnpetl\",\"level\":\"datardetawevxehuekdx\",\"\":{\"erlpr\":\"datavdovbrb\",\"jccxwbp\":\"dataaqccddcbnyg\"}}},\"description\":\"ykdigqzlrznda\",\"structure\":\"datanidmjqmvytg\",\"schema\":\"dataqlarhqt\",\"linkedServiceName\":{\"referenceName\":\"v\",\"parameters\":{\"ffzjwztsmpchggry\":\"dataekdzd\",\"atig\":\"datalgf\",\"vojtvmdevdlhqv\":\"datagfrrkdknczgoryw\"}},\"parameters\":{\"ac\":{\"type\":\"Int\",\"defaultValue\":\"datapyhssrlvkpkpkoc\"}},\"annotations\":[\"dataxxopyi\"],\"folder\":{\"name\":\"sp\"},\"\":{\"ccpumddhgajkr\":\"datahwyykgv\",\"fcudvafnbfbqv\":\"datayddt\",\"ecwzvcmbpwdluda\":\"datanqnxhgkordwzej\",\"ffbvtzldzchub\":\"dataprldidwm\"}}")
+ "{\"type\":\"AzureBlob\",\"typeProperties\":{\"folderPath\":\"datal\",\"tableRootLocation\":\"datavig\",\"fileName\":\"dataghfrbzakpjtcq\",\"modifiedDatetimeStart\":\"dataqpojpsucmximc\",\"modifiedDatetimeEnd\":\"dataxyn\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datasatkyvscb\",\"deserializer\":\"datagcru\",\"\":{\"bjolpyoklkv\":\"dataircpgcvsvkk\"}},\"compression\":{\"type\":\"datanadvhml\",\"level\":\"dataoi\",\"\":{\"mqwtqszzgy\":\"dataxxbhtpsyioq\",\"gjqcrbkompnbnfg\":\"datasikawanvmwd\"}}},\"description\":\"e\",\"structure\":\"databepgcmahiwfry\",\"schema\":\"datakchkapit\",\"linkedServiceName\":{\"referenceName\":\"kshfy\",\"parameters\":{\"nfd\":\"dataibjepzwhj\"}},\"parameters\":{\"vwehsu\":{\"type\":\"Object\",\"defaultValue\":\"datajxzhbl\"}},\"annotations\":[\"dataymbh\",\"dataosmbngkqlgxz\",\"datauvxdmxexatmd\"],\"folder\":{\"name\":\"senxoirxyd\"},\"\":{\"xznntwgkvyohp\":\"dataploisjkzs\",\"wytb\":\"dataapzupz\",\"mxpqkjnpyriwn\":\"datajzghximkg\",\"xmmqmt\":\"dataot\"}}")
.toObject(AzureBlobDataset.class);
- Assertions.assertEquals("ykdigqzlrznda", model.description());
- Assertions.assertEquals("v", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("ac").type());
- Assertions.assertEquals("sp", model.folder().name());
+ Assertions.assertEquals("e", model.description());
+ Assertions.assertEquals("kshfy", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("vwehsu").type());
+ Assertions.assertEquals("senxoirxyd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobDataset model
- = new AzureBlobDataset().withDescription("ykdigqzlrznda")
- .withStructure("datanidmjqmvytg")
- .withSchema("dataqlarhqt")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("v")
- .withParameters(mapOf("ffzjwztsmpchggry", "dataekdzd", "atig", "datalgf", "vojtvmdevdlhqv",
- "datagfrrkdknczgoryw")))
- .withParameters(mapOf("ac",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datapyhssrlvkpkpkoc")))
- .withAnnotations(Arrays.asList("dataxxopyi"))
- .withFolder(new DatasetFolder().withName("sp"))
- .withFolderPath("dataufpnezsjzaymld")
- .withTableRootLocation("datar")
- .withFileName("dataogzmsimehtcuuwdh")
- .withModifiedDatetimeStart("dataqhyhni")
- .withModifiedDatetimeEnd("datatnsugisno")
- .withFormat(new DatasetStorageFormat().withSerializer("datawnghojo")
- .withDeserializer("dataeyym")
- .withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("datadljnpetl")
- .withLevel("datardetawevxehuekdx")
- .withAdditionalProperties(mapOf()));
+ AzureBlobDataset model = new AzureBlobDataset().withDescription("e")
+ .withStructure("databepgcmahiwfry")
+ .withSchema("datakchkapit")
+ .withLinkedServiceName(
+ new LinkedServiceReference().withReferenceName("kshfy").withParameters(mapOf("nfd", "dataibjepzwhj")))
+ .withParameters(mapOf("vwehsu",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datajxzhbl")))
+ .withAnnotations(Arrays.asList("dataymbh", "dataosmbngkqlgxz", "datauvxdmxexatmd"))
+ .withFolder(new DatasetFolder().withName("senxoirxyd"))
+ .withFolderPath("datal")
+ .withTableRootLocation("datavig")
+ .withFileName("dataghfrbzakpjtcq")
+ .withModifiedDatetimeStart("dataqpojpsucmximc")
+ .withModifiedDatetimeEnd("dataxyn")
+ .withFormat(new DatasetStorageFormat().withSerializer("datasatkyvscb")
+ .withDeserializer("datagcru")
+ .withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
+ .withCompression(
+ new DatasetCompression().withType("datanadvhml").withLevel("dataoi").withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(AzureBlobDataset.class);
- Assertions.assertEquals("ykdigqzlrznda", model.description());
- Assertions.assertEquals("v", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("ac").type());
- Assertions.assertEquals("sp", model.folder().name());
+ Assertions.assertEquals("e", model.description());
+ Assertions.assertEquals("kshfy", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("vwehsu").type());
+ Assertions.assertEquals("senxoirxyd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTypePropertiesTests.java
index 3ed9702a4d2c..c9f5d0a0272f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobDatasetTypePropertiesTests.java
@@ -15,22 +15,22 @@ public final class AzureBlobDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobDatasetTypeProperties model = BinaryData.fromString(
- "{\"folderPath\":\"datawnlzuvi\",\"tableRootLocation\":\"datalghfrbzakpjtcqra\",\"fileName\":\"dataojpsucm\",\"modifiedDatetimeStart\":\"datamcwqxynqjgs\",\"modifiedDatetimeEnd\":\"datakyvscbgngcrus\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datarcpgcvsvkkjbjolp\",\"deserializer\":\"dataklkvuznadvh\",\"\":{\"emqwtq\":\"dataeoigowxxbhtpsyio\",\"mwdvgjqcrb\":\"datazzgyksikawan\",\"cmahiwfrya\":\"dataompnbnfgyweojbep\"}},\"compression\":{\"type\":\"datach\",\"level\":\"datapitskshfyftti\",\"\":{\"x\":\"datapzwhjunfdgbggc\"}}}")
+ "{\"folderPath\":\"dataky\",\"tableRootLocation\":\"dataexwdonbexf\",\"fileName\":\"datadaubheeggzgr\",\"modifiedDatetimeStart\":\"datatlfozuumrtgjqgac\",\"modifiedDatetimeEnd\":\"datatnsyxzxjm\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"databc\",\"deserializer\":\"datazofmexvtemaspm\",\"\":{\"hntofe\":\"datadscdkxwdpwjcbha\",\"fixoskk\":\"datafh\",\"zzmrgtxdhmfpp\":\"datadfivsujybsr\"}},\"compression\":{\"type\":\"datamgikesmkwt\",\"level\":\"datafragjhxerx\",\"\":{\"vmmnii\":\"datakdbtq\",\"bggicnqwlctmw\":\"datayholhjns\"}}}")
.toObject(AzureBlobDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobDatasetTypeProperties model = new AzureBlobDatasetTypeProperties().withFolderPath("datawnlzuvi")
- .withTableRootLocation("datalghfrbzakpjtcqra")
- .withFileName("dataojpsucm")
- .withModifiedDatetimeStart("datamcwqxynqjgs")
- .withModifiedDatetimeEnd("datakyvscbgngcrus")
- .withFormat(new DatasetStorageFormat().withSerializer("datarcpgcvsvkkjbjolp")
- .withDeserializer("dataklkvuznadvh")
+ AzureBlobDatasetTypeProperties model = new AzureBlobDatasetTypeProperties().withFolderPath("dataky")
+ .withTableRootLocation("dataexwdonbexf")
+ .withFileName("datadaubheeggzgr")
+ .withModifiedDatetimeStart("datatlfozuumrtgjqgac")
+ .withModifiedDatetimeEnd("datatnsyxzxjm")
+ .withFormat(new DatasetStorageFormat().withSerializer("databc")
+ .withDeserializer("datazofmexvtemaspm")
.withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("datach")
- .withLevel("datapitskshfyftti")
+ .withCompression(new DatasetCompression().withType("datamgikesmkwt")
+ .withLevel("datafragjhxerx")
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(AzureBlobDatasetTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTests.java
index 36dc9fcbf06c..3dc9b211d64c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTests.java
@@ -21,39 +21,45 @@ public final class AzureBlobFSDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobFSDataset model = BinaryData.fromString(
- "{\"type\":\"AzureBlobFSFile\",\"typeProperties\":{\"folderPath\":\"datauk\",\"fileName\":\"datagoojjfuk\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datacm\",\"deserializer\":\"datah\",\"\":{\"xvs\":\"datazv\",\"cnihkswxmfurqmw\":\"datacuufkrfn\"}},\"compression\":{\"type\":\"datawpntumotah\",\"level\":\"datasvnkxmyt\",\"\":{\"hxg\":\"dataedr\"}}},\"description\":\"myrhkvx\",\"structure\":\"datamiemqyftgpqos\",\"schema\":\"datafqvjmghpakbqyhls\",\"linkedServiceName\":{\"referenceName\":\"rnfbmeqagkn\",\"parameters\":{\"evztnjawrhul\":\"dataybn\",\"rxbkitzmnhitax\":\"datammqmbwppx\",\"vyljubvfjyzufldi\":\"dataucltjlxsgcemegdz\"}},\"parameters\":{\"zxhkl\":{\"type\":\"Int\",\"defaultValue\":\"datautggmaacxauhvc\"}},\"annotations\":[\"datatoiyygktsrjyx\"],\"folder\":{\"name\":\"wfzbkve\"},\"\":{\"vuwmsumustihtgr\":\"datafxphsowbebsnbwut\"}}")
+ "{\"type\":\"AzureBlobFSFile\",\"typeProperties\":{\"folderPath\":\"datakkvxu\",\"fileName\":\"dataqzbvbpsuvqhxt\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datagdkwbkurklpiigfu\",\"deserializer\":\"dataeutuipjclz\",\"\":{\"ydewuwxyll\":\"dataqdz\",\"k\":\"datazzevtzqwczochwb\",\"kyvnhiysdhork\":\"datauynf\",\"qki\":\"datalhr\"}},\"compression\":{\"type\":\"datawkffla\",\"level\":\"datamwqoguflteatnege\",\"\":{\"hnvxwtd\":\"dataxnjtqbgysib\",\"kxunsaujqgbb\":\"datatcbjdbtqy\",\"hgjsmbcsloy\":\"datavovoa\"}}},\"description\":\"abdgdheronsd\",\"structure\":\"datarkzvz\",\"schema\":\"datatqhgz\",\"linkedServiceName\":{\"referenceName\":\"yxtrvfdbqsk\",\"parameters\":{\"ptpvsffavdhpiw\":\"databvi\",\"bwxyldqtmggcpd\":\"datamuwkgjwbyfdw\",\"zctwymzsk\":\"datamegaj\"}},\"parameters\":{\"gliupqscoob\":{\"type\":\"Object\",\"defaultValue\":\"dataeseip\"},\"incev\":{\"type\":\"Object\",\"defaultValue\":\"datacaxsqcomjiq\"},\"duvtvod\":{\"type\":\"Int\",\"defaultValue\":\"datadevpximziizmeq\"},\"hm\":{\"type\":\"SecureString\",\"defaultValue\":\"datap\"}},\"annotations\":[\"datab\",\"datablmcvrjaznotdof\",\"datavpbqsdqkpsbqs\",\"databmitaftazgcxsvq\"],\"folder\":{\"name\":\"ufylamxowbg\"},\"\":{\"xiknsgofuns\":\"datayutehlkarvtipquk\",\"xn\":\"datahpcekggvmfnnb\"}}")
.toObject(AzureBlobFSDataset.class);
- Assertions.assertEquals("myrhkvx", model.description());
- Assertions.assertEquals("rnfbmeqagkn", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("zxhkl").type());
- Assertions.assertEquals("wfzbkve", model.folder().name());
+ Assertions.assertEquals("abdgdheronsd", model.description());
+ Assertions.assertEquals("yxtrvfdbqsk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("gliupqscoob").type());
+ Assertions.assertEquals("ufylamxowbg", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobFSDataset model = new AzureBlobFSDataset().withDescription("myrhkvx")
- .withStructure("datamiemqyftgpqos")
- .withSchema("datafqvjmghpakbqyhls")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rnfbmeqagkn")
- .withParameters(mapOf("evztnjawrhul", "dataybn", "rxbkitzmnhitax", "datammqmbwppx", "vyljubvfjyzufldi",
- "dataucltjlxsgcemegdz")))
- .withParameters(mapOf("zxhkl",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datautggmaacxauhvc")))
- .withAnnotations(Arrays.asList("datatoiyygktsrjyx"))
- .withFolder(new DatasetFolder().withName("wfzbkve"))
- .withFolderPath("datauk")
- .withFileName("datagoojjfuk")
- .withFormat(new DatasetStorageFormat().withSerializer("datacm")
- .withDeserializer("datah")
- .withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("datawpntumotah")
- .withLevel("datasvnkxmyt")
- .withAdditionalProperties(mapOf()));
+ AzureBlobFSDataset model
+ = new AzureBlobFSDataset().withDescription("abdgdheronsd")
+ .withStructure("datarkzvz")
+ .withSchema("datatqhgz")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("yxtrvfdbqsk")
+ .withParameters(mapOf("ptpvsffavdhpiw", "databvi", "bwxyldqtmggcpd", "datamuwkgjwbyfdw",
+ "zctwymzsk", "datamegaj")))
+ .withParameters(mapOf("gliupqscoob",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataeseip"), "incev",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datacaxsqcomjiq"),
+ "duvtvod",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datadevpximziizmeq"),
+ "hm", new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datap")))
+ .withAnnotations(
+ Arrays.asList("datab", "datablmcvrjaznotdof", "datavpbqsdqkpsbqs", "databmitaftazgcxsvq"))
+ .withFolder(new DatasetFolder().withName("ufylamxowbg"))
+ .withFolderPath("datakkvxu")
+ .withFileName("dataqzbvbpsuvqhxt")
+ .withFormat(new DatasetStorageFormat().withSerializer("datagdkwbkurklpiigfu")
+ .withDeserializer("dataeutuipjclz")
+ .withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
+ .withCompression(new DatasetCompression().withType("datawkffla")
+ .withLevel("datamwqoguflteatnege")
+ .withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(AzureBlobFSDataset.class);
- Assertions.assertEquals("myrhkvx", model.description());
- Assertions.assertEquals("rnfbmeqagkn", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("zxhkl").type());
- Assertions.assertEquals("wfzbkve", model.folder().name());
+ Assertions.assertEquals("abdgdheronsd", model.description());
+ Assertions.assertEquals("yxtrvfdbqsk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("gliupqscoob").type());
+ Assertions.assertEquals("ufylamxowbg", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTypePropertiesTests.java
index b84061843131..eba36702c156 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSDatasetTypePropertiesTests.java
@@ -15,21 +15,20 @@ public final class AzureBlobFSDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobFSDatasetTypeProperties model = BinaryData.fromString(
- "{\"folderPath\":\"datajajvkyxmmjczvo\",\"fileName\":\"dataderjennmk\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datauwqdwxhhlbmyphf\",\"deserializer\":\"datarpdhewokyqs\",\"\":{\"todjf\":\"datafsywbihq\",\"wcrugyozzz\":\"dataxbvkvwzdmvdd\"}},\"compression\":{\"type\":\"datanjdvv\",\"level\":\"datahocrkkvx\",\"\":{\"zfgdk\":\"dataqzbvbpsuvqhxt\",\"uzkeutuip\":\"databkurklpiig\",\"ydewuwxyll\":\"dataclzjwaqdz\",\"k\":\"datazzevtzqwczochwb\"}}}")
+ "{\"folderPath\":\"datafkk\",\"fileName\":\"dataeetxtpwcv\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datawsunjzijaciwmmpd\",\"deserializer\":\"datadonb\",\"\":{\"wsyuifkzqqhbtflo\":\"datanfzyviiwsuanz\",\"eoiipjpngvyvu\":\"datalmkf\",\"ryclo\":\"dataikdlpsxntugfwimq\",\"jeleifqhdxt\":\"datafmvswx\"}},\"compression\":{\"type\":\"dataulkrybpaev\",\"level\":\"databyjecrq\",\"\":{\"uibsd\":\"datakkchsfoulborc\",\"lp\":\"databdy\"}}}")
.toObject(AzureBlobFSDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobFSDatasetTypeProperties model
- = new AzureBlobFSDatasetTypeProperties().withFolderPath("datajajvkyxmmjczvo")
- .withFileName("dataderjennmk")
- .withFormat(new DatasetStorageFormat().withSerializer("datauwqdwxhhlbmyphf")
- .withDeserializer("datarpdhewokyqs")
- .withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("datanjdvv")
- .withLevel("datahocrkkvx")
- .withAdditionalProperties(mapOf()));
+ AzureBlobFSDatasetTypeProperties model = new AzureBlobFSDatasetTypeProperties().withFolderPath("datafkk")
+ .withFileName("dataeetxtpwcv")
+ .withFormat(new DatasetStorageFormat().withSerializer("datawsunjzijaciwmmpd")
+ .withDeserializer("datadonb")
+ .withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
+ .withCompression(new DatasetCompression().withType("dataulkrybpaev")
+ .withLevel("databyjecrq")
+ .withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(AzureBlobFSDatasetTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSReadSettingsTests.java
index f7145a486cb3..f9efd3744977 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSReadSettingsTests.java
@@ -11,23 +11,23 @@ public final class AzureBlobFSReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobFSReadSettings model = BinaryData.fromString(
- "{\"type\":\"AzureBlobFSReadSettings\",\"recursive\":\"dataeyaoyzjfgvxau\",\"wildcardFolderPath\":\"datanabgrsnfzmth\",\"wildcardFileName\":\"datacuf\",\"fileListPath\":\"datazfot\",\"enablePartitionDiscovery\":\"datakumam\",\"partitionRootPath\":\"datargljekh\",\"deleteFilesAfterCompletion\":\"datafgjbeybdukbglniw\",\"modifiedDatetimeStart\":\"datamysce\",\"modifiedDatetimeEnd\":\"datavoexkonciacdl\",\"maxConcurrentConnections\":\"datahs\",\"disableMetricsCollection\":\"datavxkctedhaf\",\"\":{\"yxy\":\"dataffajniwbyzyj\",\"dzc\":\"databbugo\"}}")
+ "{\"type\":\"AzureBlobFSReadSettings\",\"recursive\":\"dataejkvcimq\",\"wildcardFolderPath\":\"datad\",\"wildcardFileName\":\"datahhwtgcgefayc\",\"fileListPath\":\"datagotbjnxozi\",\"enablePartitionDiscovery\":\"dataxnpov\",\"partitionRootPath\":\"dataxl\",\"deleteFilesAfterCompletion\":\"datamsgdisupnxth\",\"modifiedDatetimeStart\":\"datazdvokxuyhhrdi\",\"modifiedDatetimeEnd\":\"databqeahgsibldxyaq\",\"maxConcurrentConnections\":\"dataaznz\",\"disableMetricsCollection\":\"datazfhh\",\"\":{\"ihn\":\"dataxkgnryalkfdxa\",\"dwyehqnxuffgjyn\":\"datardh\"}}")
.toObject(AzureBlobFSReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobFSReadSettings model = new AzureBlobFSReadSettings().withMaxConcurrentConnections("datahs")
- .withDisableMetricsCollection("datavxkctedhaf")
- .withRecursive("dataeyaoyzjfgvxau")
- .withWildcardFolderPath("datanabgrsnfzmth")
- .withWildcardFileName("datacuf")
- .withFileListPath("datazfot")
- .withEnablePartitionDiscovery("datakumam")
- .withPartitionRootPath("datargljekh")
- .withDeleteFilesAfterCompletion("datafgjbeybdukbglniw")
- .withModifiedDatetimeStart("datamysce")
- .withModifiedDatetimeEnd("datavoexkonciacdl");
+ AzureBlobFSReadSettings model = new AzureBlobFSReadSettings().withMaxConcurrentConnections("dataaznz")
+ .withDisableMetricsCollection("datazfhh")
+ .withRecursive("dataejkvcimq")
+ .withWildcardFolderPath("datad")
+ .withWildcardFileName("datahhwtgcgefayc")
+ .withFileListPath("datagotbjnxozi")
+ .withEnablePartitionDiscovery("dataxnpov")
+ .withPartitionRootPath("dataxl")
+ .withDeleteFilesAfterCompletion("datamsgdisupnxth")
+ .withModifiedDatetimeStart("datazdvokxuyhhrdi")
+ .withModifiedDatetimeEnd("databqeahgsibldxyaq");
model = BinaryData.fromObject(model).toObject(AzureBlobFSReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSinkTests.java
index 0deadedae971..5c2e67fa162c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSinkTests.java
@@ -13,20 +13,23 @@ public final class AzureBlobFSSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobFSSink model = BinaryData.fromString(
- "{\"type\":\"AzureBlobFSSink\",\"copyBehavior\":\"datasa\",\"metadata\":[{\"name\":\"datamcaxgtwpzqtimq\",\"value\":\"datasfaqy\"}],\"writeBatchSize\":\"datacpdtktfpjkxk\",\"writeBatchTimeout\":\"datawntnfoqwufor\",\"sinkRetryCount\":\"databe\",\"sinkRetryWait\":\"dataipnsyedpyrpips\",\"maxConcurrentConnections\":\"datafwgrz\",\"disableMetricsCollection\":\"datafbodifgh\",\"\":{\"cxoqxtjzdpl\":\"datayh\",\"osoxxoqyikdjaog\":\"datagllvkor\",\"lg\":\"datattxqxvmybq\"}}")
+ "{\"type\":\"AzureBlobFSSink\",\"copyBehavior\":\"datazmrlprbclj\",\"metadata\":[{\"name\":\"dataawnz\",\"value\":\"datafvefskjbasmrdpb\"},{\"name\":\"dataqusv\",\"value\":\"datagfzbykap\"},{\"name\":\"dataomc\",\"value\":\"datam\"},{\"name\":\"datadtg\",\"value\":\"datayubnwymyewbfoxw\"}],\"writeBatchSize\":\"dataetj\",\"writeBatchTimeout\":\"datajbahx\",\"sinkRetryCount\":\"dataddpbt\",\"sinkRetryWait\":\"datardj\",\"maxConcurrentConnections\":\"datacrmptjsixawipj\",\"disableMetricsCollection\":\"datacyxnza\",\"\":{\"dvapoh\":\"datavbkhgdzrc\"}}")
.toObject(AzureBlobFSSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobFSSink model = new AzureBlobFSSink().withWriteBatchSize("datacpdtktfpjkxk")
- .withWriteBatchTimeout("datawntnfoqwufor")
- .withSinkRetryCount("databe")
- .withSinkRetryWait("dataipnsyedpyrpips")
- .withMaxConcurrentConnections("datafwgrz")
- .withDisableMetricsCollection("datafbodifgh")
- .withCopyBehavior("datasa")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datamcaxgtwpzqtimq").withValue("datasfaqy")));
+ AzureBlobFSSink model = new AzureBlobFSSink().withWriteBatchSize("dataetj")
+ .withWriteBatchTimeout("datajbahx")
+ .withSinkRetryCount("dataddpbt")
+ .withSinkRetryWait("datardj")
+ .withMaxConcurrentConnections("datacrmptjsixawipj")
+ .withDisableMetricsCollection("datacyxnza")
+ .withCopyBehavior("datazmrlprbclj")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("dataawnz").withValue("datafvefskjbasmrdpb"),
+ new MetadataItem().withName("dataqusv").withValue("datagfzbykap"),
+ new MetadataItem().withName("dataomc").withValue("datam"),
+ new MetadataItem().withName("datadtg").withValue("datayubnwymyewbfoxw")));
model = BinaryData.fromObject(model).toObject(AzureBlobFSSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSourceTests.java
index 5c97a07a9243..09bd1339c126 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSSourceTests.java
@@ -11,19 +11,19 @@ public final class AzureBlobFSSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobFSSource model = BinaryData.fromString(
- "{\"type\":\"AzureBlobFSSource\",\"treatEmptyAsNull\":\"datadexnicq\",\"skipHeaderLineCount\":\"datafqttfqgdoowgqooi\",\"recursive\":\"datahsvsnedhkji\",\"sourceRetryCount\":\"datavetwf\",\"sourceRetryWait\":\"dataqvflrrtj\",\"maxConcurrentConnections\":\"dataikqzd\",\"disableMetricsCollection\":\"dataqalxpmiytpjis\",\"\":{\"pvlsljutawg\":\"dataolkw\",\"ehlopipvpeaeyj\":\"datalnodrfc\",\"vcbm\":\"datayxduxhopy\",\"qxjoazyxmum\":\"dataembvfa\"}}")
+ "{\"type\":\"AzureBlobFSSource\",\"treatEmptyAsNull\":\"databtuujcuavctxyrm\",\"skipHeaderLineCount\":\"datahrzmy\",\"recursive\":\"datan\",\"sourceRetryCount\":\"dataajxv\",\"sourceRetryWait\":\"dataidlwmewrgu\",\"maxConcurrentConnections\":\"dataugpkunvygupgnnvm\",\"disableMetricsCollection\":\"datazqmxwwmekms\",\"\":{\"x\":\"datajbefszfrxfywjy\",\"mykgrtwh\":\"dataqmdeecdhyjsizyhp\",\"hismw\":\"dataa\"}}")
.toObject(AzureBlobFSSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobFSSource model = new AzureBlobFSSource().withSourceRetryCount("datavetwf")
- .withSourceRetryWait("dataqvflrrtj")
- .withMaxConcurrentConnections("dataikqzd")
- .withDisableMetricsCollection("dataqalxpmiytpjis")
- .withTreatEmptyAsNull("datadexnicq")
- .withSkipHeaderLineCount("datafqttfqgdoowgqooi")
- .withRecursive("datahsvsnedhkji");
+ AzureBlobFSSource model = new AzureBlobFSSource().withSourceRetryCount("dataajxv")
+ .withSourceRetryWait("dataidlwmewrgu")
+ .withMaxConcurrentConnections("dataugpkunvygupgnnvm")
+ .withDisableMetricsCollection("datazqmxwwmekms")
+ .withTreatEmptyAsNull("databtuujcuavctxyrm")
+ .withSkipHeaderLineCount("datahrzmy")
+ .withRecursive("datan");
model = BinaryData.fromObject(model).toObject(AzureBlobFSSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSWriteSettingsTests.java
index 81c75d44504a..1bae2739bc90 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobFSWriteSettingsTests.java
@@ -13,17 +13,18 @@ public final class AzureBlobFSWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobFSWriteSettings model = BinaryData.fromString(
- "{\"type\":\"AzureBlobFSWriteSettings\",\"blockSizeInMB\":\"datapkdsldy\",\"maxConcurrentConnections\":\"datawvswlhjlbkq\",\"disableMetricsCollection\":\"dataszhpnatltjek\",\"copyBehavior\":\"datafwlkyrnmgsbubzfa\",\"metadata\":[{\"name\":\"dataec\",\"value\":\"datatrederz\"}],\"\":{\"smvvfpkymqnvvwfa\":\"datagmohhcgh\",\"armtuprqtcxqkoh\":\"datarulboawzplwghfgq\",\"kdejparjvsbo\":\"datapya\"}}")
+ "{\"type\":\"AzureBlobFSWriteSettings\",\"blockSizeInMB\":\"dataikedmou\",\"maxConcurrentConnections\":\"datauqo\",\"disableMetricsCollection\":\"dataic\",\"copyBehavior\":\"datayjszmleuqxhmrilw\",\"metadata\":[{\"name\":\"datasvpv\",\"value\":\"dataulxxznfxdqqzi\"},{\"name\":\"datagwqi\",\"value\":\"datadhas\"}],\"\":{\"tdmhr\":\"dataaexrzxvffqc\"}}")
.toObject(AzureBlobFSWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureBlobFSWriteSettings model = new AzureBlobFSWriteSettings().withMaxConcurrentConnections("datawvswlhjlbkq")
- .withDisableMetricsCollection("dataszhpnatltjek")
- .withCopyBehavior("datafwlkyrnmgsbubzfa")
- .withMetadata(Arrays.asList(new MetadataItem().withName("dataec").withValue("datatrederz")))
- .withBlockSizeInMB("datapkdsldy");
+ AzureBlobFSWriteSettings model = new AzureBlobFSWriteSettings().withMaxConcurrentConnections("datauqo")
+ .withDisableMetricsCollection("dataic")
+ .withCopyBehavior("datayjszmleuqxhmrilw")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datasvpv").withValue("dataulxxznfxdqqzi"),
+ new MetadataItem().withName("datagwqi").withValue("datadhas")))
+ .withBlockSizeInMB("dataikedmou");
model = BinaryData.fromObject(model).toObject(AzureBlobFSWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageReadSettingsTests.java
index 5a6f0f465dfa..c3d04a8439e9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageReadSettingsTests.java
@@ -11,25 +11,25 @@ public final class AzureBlobStorageReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobStorageReadSettings model = BinaryData.fromString(
- "{\"type\":\"AzureBlobStorageReadSettings\",\"recursive\":\"dataljcauegymc\",\"wildcardFolderPath\":\"datasmnjitxu\",\"wildcardFileName\":\"datalbibwodayipgsh\",\"prefix\":\"dataoecmbyo\",\"fileListPath\":\"datavbvfchfuxuqp\",\"enablePartitionDiscovery\":\"dataebok\",\"partitionRootPath\":\"datashhhdixnzapz\",\"deleteFilesAfterCompletion\":\"datamstvz\",\"modifiedDatetimeStart\":\"datazvfywspajakj\",\"modifiedDatetimeEnd\":\"datapktbnmhxtmzzpa\",\"maxConcurrentConnections\":\"datasrvsbkn\",\"disableMetricsCollection\":\"datauytsaj\",\"\":{\"j\":\"datausnwic\",\"btegiw\":\"datawctlsohrtgpvv\"}}")
+ "{\"type\":\"AzureBlobStorageReadSettings\",\"recursive\":\"datazcjmsrorjby\",\"wildcardFolderPath\":\"datakcvahvby\",\"wildcardFileName\":\"datat\",\"prefix\":\"datavwvengicyc\",\"fileListPath\":\"datakhgjyho\",\"enablePartitionDiscovery\":\"datamahbj\",\"partitionRootPath\":\"datavskqxgb\",\"deleteFilesAfterCompletion\":\"dataozrvlklaurl\",\"modifiedDatetimeStart\":\"dataseocp\",\"modifiedDatetimeEnd\":\"datasfj\",\"maxConcurrentConnections\":\"datagmogmcjn\",\"disableMetricsCollection\":\"dataukbwypcvqfz\",\"\":{\"erizf\":\"datax\",\"cdpyoqmwpmrlgj\":\"datawlkovopqp\",\"fptvam\":\"dataqs\"}}")
.toObject(AzureBlobStorageReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureBlobStorageReadSettings model
- = new AzureBlobStorageReadSettings().withMaxConcurrentConnections("datasrvsbkn")
- .withDisableMetricsCollection("datauytsaj")
- .withRecursive("dataljcauegymc")
- .withWildcardFolderPath("datasmnjitxu")
- .withWildcardFileName("datalbibwodayipgsh")
- .withPrefix("dataoecmbyo")
- .withFileListPath("datavbvfchfuxuqp")
- .withEnablePartitionDiscovery("dataebok")
- .withPartitionRootPath("datashhhdixnzapz")
- .withDeleteFilesAfterCompletion("datamstvz")
- .withModifiedDatetimeStart("datazvfywspajakj")
- .withModifiedDatetimeEnd("datapktbnmhxtmzzpa");
+ = new AzureBlobStorageReadSettings().withMaxConcurrentConnections("datagmogmcjn")
+ .withDisableMetricsCollection("dataukbwypcvqfz")
+ .withRecursive("datazcjmsrorjby")
+ .withWildcardFolderPath("datakcvahvby")
+ .withWildcardFileName("datat")
+ .withPrefix("datavwvengicyc")
+ .withFileListPath("datakhgjyho")
+ .withEnablePartitionDiscovery("datamahbj")
+ .withPartitionRootPath("datavskqxgb")
+ .withDeleteFilesAfterCompletion("dataozrvlklaurl")
+ .withModifiedDatetimeStart("dataseocp")
+ .withModifiedDatetimeEnd("datasfj");
model = BinaryData.fromObject(model).toObject(AzureBlobStorageReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageWriteSettingsTests.java
index 80565fdb1635..eddb312ba3ad 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureBlobStorageWriteSettingsTests.java
@@ -13,19 +13,20 @@ public final class AzureBlobStorageWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureBlobStorageWriteSettings model = BinaryData.fromString(
- "{\"type\":\"AzureBlobStorageWriteSettings\",\"blockSizeInMB\":\"datadcokbpbpqe\",\"maxConcurrentConnections\":\"dataszobtneltnby\",\"disableMetricsCollection\":\"datagrdrum\",\"copyBehavior\":\"datau\",\"metadata\":[{\"name\":\"datadsybiazfvxdkwvc\",\"value\":\"datalyxbyqqonkrekioj\"}],\"\":{\"yykx\":\"datadodkukycntaov\"}}")
+ "{\"type\":\"AzureBlobStorageWriteSettings\",\"blockSizeInMB\":\"datasvexzyjfwi\",\"maxConcurrentConnections\":\"datamqutgxdlznfokc\",\"disableMetricsCollection\":\"datarskyl\",\"copyBehavior\":\"datapp\",\"metadata\":[{\"name\":\"datakktretutsy\",\"value\":\"datajpla\"},{\"name\":\"datafnrltanvb\",\"value\":\"dataotghxkrrpmgdoli\"},{\"name\":\"datazsglavdtttyd\",\"value\":\"dataomz\"}],\"\":{\"vey\":\"datajqcshbypw\"}}")
.toObject(AzureBlobStorageWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureBlobStorageWriteSettings model
- = new AzureBlobStorageWriteSettings().withMaxConcurrentConnections("dataszobtneltnby")
- .withDisableMetricsCollection("datagrdrum")
- .withCopyBehavior("datau")
- .withMetadata(
- Arrays.asList(new MetadataItem().withName("datadsybiazfvxdkwvc").withValue("datalyxbyqqonkrekioj")))
- .withBlockSizeInMB("datadcokbpbpqe");
+ = new AzureBlobStorageWriteSettings().withMaxConcurrentConnections("datamqutgxdlznfokc")
+ .withDisableMetricsCollection("datarskyl")
+ .withCopyBehavior("datapp")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datakktretutsy").withValue("datajpla"),
+ new MetadataItem().withName("datafnrltanvb").withValue("dataotghxkrrpmgdoli"),
+ new MetadataItem().withName("datazsglavdtttyd").withValue("dataomz")))
+ .withBlockSizeInMB("datasvexzyjfwi");
model = BinaryData.fromObject(model).toObject(AzureBlobStorageWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTests.java
index 388e2a7f72ed..bd3f5bcad827 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTests.java
@@ -22,65 +22,63 @@ public final class AzureDataExplorerCommandActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataExplorerCommandActivity model = BinaryData.fromString(
- "{\"type\":\"AzureDataExplorerCommand\",\"typeProperties\":{\"command\":\"datarkkankjk\",\"commandTimeout\":\"dataudxq\"},\"linkedServiceName\":{\"referenceName\":\"vxvoqbruyma\",\"parameters\":{\"jfmvydjax\":\"datafofxi\",\"vugb\":\"datastuhlwzcn\"}},\"policy\":{\"timeout\":\"datayfhkx\",\"retry\":\"datalhqzpw\",\"retryIntervalInSeconds\":1378860683,\"secureInput\":false,\"secureOutput\":false,\"\":{\"cnfgtup\":\"datae\",\"dzqxkgr\":\"dataqfupoamc\"}},\"name\":\"cnqipskpynrsacdc\",\"description\":\"utahlhiqodx\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"jnfd\",\"dependencyConditions\":[\"Completed\",\"Succeeded\"],\"\":{\"uucojki\":\"datahfnji\",\"kvhldnscx\":\"datagb\"}},{\"activity\":\"jwsrdzmbzlfzy\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Succeeded\"],\"\":{\"wkhipaodohb\":\"dataseehvmtyubvdou\",\"gokpnbmhskhjjxe\":\"datadbbweaa\"}},{\"activity\":\"mbuhkcsh\",\"dependencyConditions\":[\"Completed\"],\"\":{\"npftwgt\":\"datamtevifeoijep\",\"njpwkwxnmqmytv\":\"datacccyiuehsne\"}},{\"activity\":\"rjutyfn\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Failed\"],\"\":{\"jntnlbsvt\":\"dataedqakhcc\",\"rbqbyxuupqkbbem\":\"datajvdvzafpv\",\"fsjpvjwbxlgpepx\":\"datawtmeqt\"}}],\"userProperties\":[{\"name\":\"nxdgneg\",\"value\":\"datalt\"}],\"\":{\"hmvadasuevu\":\"databepmm\"}}")
+ "{\"type\":\"AzureDataExplorerCommand\",\"typeProperties\":{\"command\":\"datamnyfhkxcplhqzpw\",\"commandTimeout\":\"datauyrpsl\"},\"linkedServiceName\":{\"referenceName\":\"acn\",\"parameters\":{\"amcsdzqxkg\":\"dataupjqfup\",\"acd\":\"dataecnqipskpynr\",\"qodxsscirgqjnfde\":\"datafwutahlh\"}},\"policy\":{\"timeout\":\"dataeyhfnjifuucojkik\",\"retry\":\"datahkvhld\",\"retryIntervalInSeconds\":919721101,\"secureInput\":true,\"secureOutput\":false,\"\":{\"wexoyfsee\":\"datadzmbzlfzy\",\"doufwkhipaodohb\":\"datavmtyub\",\"gokpnbmhskhjjxe\":\"datadbbweaa\",\"h\":\"datambuhkcsh\"}},\"name\":\"ahmtevifeo\",\"description\":\"eppnpftwgtrcccyi\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"njpwkwxnmqmytv\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"haeedqa\":\"datafnmwm\",\"ntnlbsv\":\"datahccw\",\"zafpvwrbqbyxu\":\"datasjvd\"}},{\"activity\":\"pqkbbemh\",\"dependencyConditions\":[\"Completed\",\"Skipped\"],\"\":{\"pxbjjnxdgnegkltl\":\"datasfsjpvjwbxlgp\",\"mm\":\"databbe\",\"tdzgngnuuz\":\"datahmvadasuevu\",\"mnelqlqn\":\"datahgfojdbov\"}},{\"activity\":\"vqmxzdi\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"bwakmibiylkfnedx\":\"datapqsjzgncyksblre\"}}],\"userProperties\":[{\"name\":\"cyrblwqhzyr\",\"value\":\"datags\"},{\"name\":\"bzpozqluuaugktt\",\"value\":\"datapw\"}],\"\":{\"b\":\"dataajevw\"}}")
.toObject(AzureDataExplorerCommandActivity.class);
- Assertions.assertEquals("cnqipskpynrsacdc", model.name());
- Assertions.assertEquals("utahlhiqodx", model.description());
+ Assertions.assertEquals("ahmtevifeo", model.name());
+ Assertions.assertEquals("eppnpftwgtrcccyi", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("jnfd", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("njpwkwxnmqmytv", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("nxdgneg", model.userProperties().get(0).name());
- Assertions.assertEquals("vxvoqbruyma", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1378860683, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals("cyrblwqhzyr", model.userProperties().get(0).name());
+ Assertions.assertEquals("acn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(919721101, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(true, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDataExplorerCommandActivity model = new AzureDataExplorerCommandActivity().withName("cnqipskpynrsacdc")
- .withDescription("utahlhiqodx")
+ AzureDataExplorerCommandActivity model = new AzureDataExplorerCommandActivity().withName("ahmtevifeo")
+ .withDescription("eppnpftwgtrcccyi")
.withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("jnfd")
+ new ActivityDependency().withActivity("njpwkwxnmqmytv")
.withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("jwsrdzmbzlfzy")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("pqkbbemh")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("mbuhkcsh")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("rjutyfn")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED,
- DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("vqmxzdi")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("nxdgneg").withValue("datalt")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vxvoqbruyma")
- .withParameters(mapOf("jfmvydjax", "datafofxi", "vugb", "datastuhlwzcn")))
- .withPolicy(new ActivityPolicy().withTimeout("datayfhkx")
- .withRetry("datalhqzpw")
- .withRetryIntervalInSeconds(1378860683)
- .withSecureInput(false)
+ .withUserProperties(Arrays.asList(new UserProperty().withName("cyrblwqhzyr").withValue("datags"),
+ new UserProperty().withName("bzpozqluuaugktt").withValue("datapw")))
+ .withLinkedServiceName(
+ new LinkedServiceReference().withReferenceName("acn")
+ .withParameters(mapOf("amcsdzqxkg", "dataupjqfup", "acd", "dataecnqipskpynr", "qodxsscirgqjnfde",
+ "datafwutahlh")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataeyhfnjifuucojkik")
+ .withRetry("datahkvhld")
+ .withRetryIntervalInSeconds(919721101)
+ .withSecureInput(true)
.withSecureOutput(false)
.withAdditionalProperties(mapOf()))
- .withCommand("datarkkankjk")
- .withCommandTimeout("dataudxq");
+ .withCommand("datamnyfhkxcplhqzpw")
+ .withCommandTimeout("datauyrpsl");
model = BinaryData.fromObject(model).toObject(AzureDataExplorerCommandActivity.class);
- Assertions.assertEquals("cnqipskpynrsacdc", model.name());
- Assertions.assertEquals("utahlhiqodx", model.description());
+ Assertions.assertEquals("ahmtevifeo", model.name());
+ Assertions.assertEquals("eppnpftwgtrcccyi", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("jnfd", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("njpwkwxnmqmytv", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("nxdgneg", model.userProperties().get(0).name());
- Assertions.assertEquals("vxvoqbruyma", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1378860683, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals("cyrblwqhzyr", model.userProperties().get(0).name());
+ Assertions.assertEquals("acn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(919721101, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(true, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTypePropertiesTests.java
index 8e36d87685da..7a62a114fc58 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerCommandActivityTypePropertiesTests.java
@@ -11,15 +11,15 @@ public final class AzureDataExplorerCommandActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataExplorerCommandActivityTypeProperties model
- = BinaryData.fromString("{\"command\":\"datatdzgngnuuz\",\"commandTimeout\":\"datagfojdb\"}")
+ = BinaryData.fromString("{\"command\":\"dataqdotqe\",\"commandTimeout\":\"dataenteucaojj\"}")
.toObject(AzureDataExplorerCommandActivityTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDataExplorerCommandActivityTypeProperties model
- = new AzureDataExplorerCommandActivityTypeProperties().withCommand("datatdzgngnuuz")
- .withCommandTimeout("datagfojdb");
+ = new AzureDataExplorerCommandActivityTypeProperties().withCommand("dataqdotqe")
+ .withCommandTimeout("dataenteucaojj");
model = BinaryData.fromObject(model).toObject(AzureDataExplorerCommandActivityTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerDatasetTypePropertiesTests.java
index a66ecd68f4d7..93019880a52e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class AzureDataExplorerDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- AzureDataExplorerDatasetTypeProperties model = BinaryData.fromString("{\"table\":\"dataysyajmm\"}")
+ AzureDataExplorerDatasetTypeProperties model = BinaryData.fromString("{\"table\":\"datajxxpxxizchmb\"}")
.toObject(AzureDataExplorerDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDataExplorerDatasetTypeProperties model
- = new AzureDataExplorerDatasetTypeProperties().withTable("dataysyajmm");
+ = new AzureDataExplorerDatasetTypeProperties().withTable("datajxxpxxizchmb");
model = BinaryData.fromObject(model).toObject(AzureDataExplorerDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSinkTests.java
index e94332518e2d..ccb434363f64 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSinkTests.java
@@ -11,21 +11,21 @@ public final class AzureDataExplorerSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataExplorerSink model = BinaryData.fromString(
- "{\"type\":\"AzureDataExplorerSink\",\"ingestionMappingName\":\"dataktlzngidgwsco\",\"ingestionMappingAsJson\":\"datahgzapcgdk\",\"flushImmediately\":\"dataa\",\"writeBatchSize\":\"datacpohlfvsb\",\"writeBatchTimeout\":\"datadgzbjb\",\"sinkRetryCount\":\"dataoudc\",\"sinkRetryWait\":\"datalkucxtyufsouhkmc\",\"maxConcurrentConnections\":\"datauomdlspsbg\",\"disableMetricsCollection\":\"datanygroqia\",\"\":{\"yjox\":\"dataoxwndf\",\"ambzprhpwwarz\":\"dataalcyflzuztdwxr\",\"vj\":\"datazbbwtagxhrir\"}}")
+ "{\"type\":\"AzureDataExplorerSink\",\"ingestionMappingName\":\"datalvvazujc\",\"ingestionMappingAsJson\":\"dataznwlxzmszxyfa\",\"flushImmediately\":\"datazvdqvdivzjy\",\"writeBatchSize\":\"datajb\",\"writeBatchTimeout\":\"datalxjbrqbut\",\"sinkRetryCount\":\"datacnqudm\",\"sinkRetryWait\":\"datauvaweajq\",\"maxConcurrentConnections\":\"datavbvkwr\",\"disableMetricsCollection\":\"datazoqyymhdbg\",\"\":{\"cqqgrsyttosnzb\":\"dataltmpa\",\"vpbwt\":\"dataxifacrhpuzcagz\"}}")
.toObject(AzureDataExplorerSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDataExplorerSink model = new AzureDataExplorerSink().withWriteBatchSize("datacpohlfvsb")
- .withWriteBatchTimeout("datadgzbjb")
- .withSinkRetryCount("dataoudc")
- .withSinkRetryWait("datalkucxtyufsouhkmc")
- .withMaxConcurrentConnections("datauomdlspsbg")
- .withDisableMetricsCollection("datanygroqia")
- .withIngestionMappingName("dataktlzngidgwsco")
- .withIngestionMappingAsJson("datahgzapcgdk")
- .withFlushImmediately("dataa");
+ AzureDataExplorerSink model = new AzureDataExplorerSink().withWriteBatchSize("datajb")
+ .withWriteBatchTimeout("datalxjbrqbut")
+ .withSinkRetryCount("datacnqudm")
+ .withSinkRetryWait("datauvaweajq")
+ .withMaxConcurrentConnections("datavbvkwr")
+ .withDisableMetricsCollection("datazoqyymhdbg")
+ .withIngestionMappingName("datalvvazujc")
+ .withIngestionMappingAsJson("dataznwlxzmszxyfa")
+ .withFlushImmediately("datazvdqvdivzjy");
model = BinaryData.fromObject(model).toObject(AzureDataExplorerSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSourceTests.java
index f152249bab98..112a310be4d5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerSourceTests.java
@@ -11,20 +11,20 @@ public final class AzureDataExplorerSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataExplorerSource model = BinaryData.fromString(
- "{\"type\":\"AzureDataExplorerSource\",\"query\":\"datapzhuhuj\",\"noTruncation\":\"datajsez\",\"queryTimeout\":\"datahipteo\",\"additionalColumns\":\"datadnhwdfxgec\",\"sourceRetryCount\":\"datakkdbzbhsnimompxd\",\"sourceRetryWait\":\"datap\",\"maxConcurrentConnections\":\"databdmoawh\",\"disableMetricsCollection\":\"dataxxnmyxzh\",\"\":{\"dq\":\"dataqo\",\"wywayjinlsk\":\"datazhfnylgbwdsa\"}}")
+ "{\"type\":\"AzureDataExplorerSource\",\"query\":\"datacfkc\",\"noTruncation\":\"datamoonnriah\",\"queryTimeout\":\"datagzkdbmjzob\",\"additionalColumns\":\"datavbbuuipel\",\"sourceRetryCount\":\"dataptteojxhwgja\",\"sourceRetryWait\":\"datagrpwjgkxvkj\",\"maxConcurrentConnections\":\"datasl\",\"disableMetricsCollection\":\"datamm\",\"\":{\"hubgaaaxigafah\":\"datazxsvwqiwgjw\",\"gzd\":\"datatoo\",\"plavgfbvr\":\"datablpdtcyvgbhb\",\"we\":\"datahwuex\"}}")
.toObject(AzureDataExplorerSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDataExplorerSource model = new AzureDataExplorerSource().withSourceRetryCount("datakkdbzbhsnimompxd")
- .withSourceRetryWait("datap")
- .withMaxConcurrentConnections("databdmoawh")
- .withDisableMetricsCollection("dataxxnmyxzh")
- .withQuery("datapzhuhuj")
- .withNoTruncation("datajsez")
- .withQueryTimeout("datahipteo")
- .withAdditionalColumns("datadnhwdfxgec");
+ AzureDataExplorerSource model = new AzureDataExplorerSource().withSourceRetryCount("dataptteojxhwgja")
+ .withSourceRetryWait("datagrpwjgkxvkj")
+ .withMaxConcurrentConnections("datasl")
+ .withDisableMetricsCollection("datamm")
+ .withQuery("datacfkc")
+ .withNoTruncation("datamoonnriah")
+ .withQueryTimeout("datagzkdbmjzob")
+ .withAdditionalColumns("datavbbuuipel");
model = BinaryData.fromObject(model).toObject(AzureDataExplorerSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerTableDatasetTests.java
index 77680b9cc4a4..685c9bd75f1d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataExplorerTableDatasetTests.java
@@ -19,34 +19,34 @@ public final class AzureDataExplorerTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataExplorerTableDataset model = BinaryData.fromString(
- "{\"type\":\"AzureDataExplorerTable\",\"typeProperties\":{\"table\":\"datarwxxqkwargcbgdg\"},\"description\":\"ijiqe\",\"structure\":\"datawqykmvugflh\",\"schema\":\"dataoxu\",\"linkedServiceName\":{\"referenceName\":\"hcnnkvthwtam\",\"parameters\":{\"cocdxvbeqzjd\":\"datagyvxhfmuhkezuucq\"}},\"parameters\":{\"my\":{\"type\":\"Array\",\"defaultValue\":\"datapdwnee\"},\"jrwvnffaofkvfru\":{\"type\":\"Bool\",\"defaultValue\":\"datau\"},\"tvymdqaymqmyrn\":{\"type\":\"Int\",\"defaultValue\":\"datafbvhgykzov\"}},\"annotations\":[\"databqkfnoxhvo\",\"datajdgfkr\"],\"folder\":{\"name\":\"rvpa\"},\"\":{\"ej\":\"datadeex\",\"nxbohpzurn\":\"datagu\",\"oijoxcbpkiwse\":\"dataoytkbeadyfenro\",\"ztdacrqcwkk\":\"datacbtaxdrpanhsxwhx\"}}")
+ "{\"type\":\"AzureDataExplorerTable\",\"typeProperties\":{\"table\":\"datausfdywqrq\"},\"description\":\"wkendgr\",\"structure\":\"dataff\",\"schema\":\"dataqqnugtcuyuwgnyj\",\"linkedServiceName\":{\"referenceName\":\"iuj\",\"parameters\":{\"tuajkufpvvdgnme\":\"datawmlfzlhibfmcoxb\",\"bfyqz\":\"dataomnobbaibc\"}},\"parameters\":{\"buhdnhhcmtslptbd\":{\"type\":\"Float\",\"defaultValue\":\"datafgvmrkmgifmy\"},\"zjzzb\":{\"type\":\"String\",\"defaultValue\":\"datahblqivcnuqf\"},\"trch\":{\"type\":\"Array\",\"defaultValue\":\"datat\"}},\"annotations\":[\"dataruawqe\",\"dataqsqmiekx\",\"datap\",\"dataqchf\"],\"folder\":{\"name\":\"kkvjjl\"},\"\":{\"zyqokbgum\":\"datacu\"}}")
.toObject(AzureDataExplorerTableDataset.class);
- Assertions.assertEquals("ijiqe", model.description());
- Assertions.assertEquals("hcnnkvthwtam", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("my").type());
- Assertions.assertEquals("rvpa", model.folder().name());
+ Assertions.assertEquals("wkendgr", model.description());
+ Assertions.assertEquals("iuj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("buhdnhhcmtslptbd").type());
+ Assertions.assertEquals("kkvjjl", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDataExplorerTableDataset model = new AzureDataExplorerTableDataset().withDescription("ijiqe")
- .withStructure("datawqykmvugflh")
- .withSchema("dataoxu")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hcnnkvthwtam")
- .withParameters(mapOf("cocdxvbeqzjd", "datagyvxhfmuhkezuucq")))
- .withParameters(mapOf("my",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datapdwnee"),
- "jrwvnffaofkvfru", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datau"),
- "tvymdqaymqmyrn",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datafbvhgykzov")))
- .withAnnotations(Arrays.asList("databqkfnoxhvo", "datajdgfkr"))
- .withFolder(new DatasetFolder().withName("rvpa"))
- .withTable("datarwxxqkwargcbgdg");
+ AzureDataExplorerTableDataset model = new AzureDataExplorerTableDataset().withDescription("wkendgr")
+ .withStructure("dataff")
+ .withSchema("dataqqnugtcuyuwgnyj")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("iuj")
+ .withParameters(mapOf("tuajkufpvvdgnme", "datawmlfzlhibfmcoxb", "bfyqz", "dataomnobbaibc")))
+ .withParameters(mapOf("buhdnhhcmtslptbd",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datafgvmrkmgifmy"),
+ "zjzzb",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datahblqivcnuqf"), "trch",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datat")))
+ .withAnnotations(Arrays.asList("dataruawqe", "dataqsqmiekx", "datap", "dataqchf"))
+ .withFolder(new DatasetFolder().withName("kkvjjl"))
+ .withTable("datausfdywqrq");
model = BinaryData.fromObject(model).toObject(AzureDataExplorerTableDataset.class);
- Assertions.assertEquals("ijiqe", model.description());
- Assertions.assertEquals("hcnnkvthwtam", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("my").type());
- Assertions.assertEquals("rvpa", model.folder().name());
+ Assertions.assertEquals("wkendgr", model.description());
+ Assertions.assertEquals("iuj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("buhdnhhcmtslptbd").type());
+ Assertions.assertEquals("kkvjjl", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTests.java
index c7c9684c4cd5..f5c7d3fc4aa2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTests.java
@@ -21,39 +21,41 @@ public final class AzureDataLakeStoreDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataLakeStoreDataset model = BinaryData.fromString(
- "{\"type\":\"AzureDataLakeStoreFile\",\"typeProperties\":{\"folderPath\":\"datajmdgjvxlhmpmhe\",\"fileName\":\"datayaphqeofytlsnlo\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datamcqixuanccqvjf\",\"deserializer\":\"datafqpmquxpj\",\"\":{\"gugrblwa\":\"dataaaradciovmuf\"}},\"compression\":{\"type\":\"dataossnq\",\"level\":\"dataaotbptgcsm\",\"\":{\"ecvtamqwzmno\":\"dataxrwqfmd\",\"wpsibxovuqoq\":\"datafe\",\"ycvtqnzjcy\":\"datarkblndyclw\",\"alb\":\"dataqzhembtbw\"}}},\"description\":\"pisjdleajv\",\"structure\":\"datavl\",\"schema\":\"dataubsfxip\",\"linkedServiceName\":{\"referenceName\":\"eopsk\",\"parameters\":{\"cdhus\":\"datajomlupfazus\",\"rgdqyxaj\":\"datagdw\"}},\"parameters\":{\"oqzkmqcwwsjnki\":{\"type\":\"Object\",\"defaultValue\":\"dataavqcwy\"},\"sqxile\":{\"type\":\"SecureString\",\"defaultValue\":\"datapbntqqwwgf\"}},\"annotations\":[\"datasewrzne\",\"datauqynttwk\"],\"folder\":{\"name\":\"jksb\"},\"\":{\"bssfcriqx\":\"datagjmqjhgcydijnmcv\",\"vcdkucpxpyafrwr\":\"dataixtdlxw\",\"krspnrsjsemlz\":\"dataorogeuv\"}}")
+ "{\"type\":\"AzureDataLakeStoreFile\",\"typeProperties\":{\"folderPath\":\"datawgr\",\"fileName\":\"databwudhvosgjzs\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datazalivdfwgq\",\"deserializer\":\"dataewcffrxgg\",\"\":{\"priqissener\":\"datah\",\"ujyduonbdawsao\":\"datausyzaivnpsjnpckp\"}},\"compression\":{\"type\":\"datavvm\",\"level\":\"datakxjarsbbdddw\",\"\":{\"kdyqjvz\":\"dataxailx\"}}},\"description\":\"grdspzesfkqq\",\"structure\":\"datahvzf\",\"schema\":\"datarouszxacdwukokgo\",\"linkedServiceName\":{\"referenceName\":\"j\",\"parameters\":{\"tzvxxvsb\":\"dataktubcmunhg\",\"furqm\":\"datauufkrfnkcnihkswx\",\"motahbqsvnk\":\"datamwwpnt\",\"gc\":\"datamytzuaedrlh\"}},\"parameters\":{\"yftgpqoswgfqv\":{\"type\":\"Int\",\"defaultValue\":\"datakvxzzmiem\"},\"qyhls\":{\"type\":\"Array\",\"defaultValue\":\"datahpak\"},\"gkncjm\":{\"type\":\"String\",\"defaultValue\":\"datafbmeq\"}},\"annotations\":[\"datayevztnjaw\",\"datahul\",\"datammqmbwppx\",\"datarxbkitzmnhitax\"],\"folder\":{\"name\":\"l\"},\"\":{\"dvyljubvfjy\":\"dataxsgcemegd\",\"ifnivlut\":\"dataufl\",\"aacxauhvc\":\"datag\"}}")
.toObject(AzureDataLakeStoreDataset.class);
- Assertions.assertEquals("pisjdleajv", model.description());
- Assertions.assertEquals("eopsk", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("oqzkmqcwwsjnki").type());
- Assertions.assertEquals("jksb", model.folder().name());
+ Assertions.assertEquals("grdspzesfkqq", model.description());
+ Assertions.assertEquals("j", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("yftgpqoswgfqv").type());
+ Assertions.assertEquals("l", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDataLakeStoreDataset model = new AzureDataLakeStoreDataset().withDescription("pisjdleajv")
- .withStructure("datavl")
- .withSchema("dataubsfxip")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("eopsk")
- .withParameters(mapOf("cdhus", "datajomlupfazus", "rgdqyxaj", "datagdw")))
- .withParameters(mapOf("oqzkmqcwwsjnki",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataavqcwy"), "sqxile",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datapbntqqwwgf")))
- .withAnnotations(Arrays.asList("datasewrzne", "datauqynttwk"))
- .withFolder(new DatasetFolder().withName("jksb"))
- .withFolderPath("datajmdgjvxlhmpmhe")
- .withFileName("datayaphqeofytlsnlo")
- .withFormat(new DatasetStorageFormat().withSerializer("datamcqixuanccqvjf")
- .withDeserializer("datafqpmquxpj")
+ AzureDataLakeStoreDataset model = new AzureDataLakeStoreDataset().withDescription("grdspzesfkqq")
+ .withStructure("datahvzf")
+ .withSchema("datarouszxacdwukokgo")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("j")
+ .withParameters(mapOf("tzvxxvsb", "dataktubcmunhg", "furqm", "datauufkrfnkcnihkswx", "motahbqsvnk",
+ "datamwwpnt", "gc", "datamytzuaedrlh")))
+ .withParameters(mapOf("yftgpqoswgfqv",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datakvxzzmiem"), "qyhls",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datahpak"), "gkncjm",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datafbmeq")))
+ .withAnnotations(Arrays.asList("datayevztnjaw", "datahul", "datammqmbwppx", "datarxbkitzmnhitax"))
+ .withFolder(new DatasetFolder().withName("l"))
+ .withFolderPath("datawgr")
+ .withFileName("databwudhvosgjzs")
+ .withFormat(new DatasetStorageFormat().withSerializer("datazalivdfwgq")
+ .withDeserializer("dataewcffrxgg")
.withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("dataossnq")
- .withLevel("dataaotbptgcsm")
+ .withCompression(new DatasetCompression().withType("datavvm")
+ .withLevel("datakxjarsbbdddw")
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(AzureDataLakeStoreDataset.class);
- Assertions.assertEquals("pisjdleajv", model.description());
- Assertions.assertEquals("eopsk", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("oqzkmqcwwsjnki").type());
- Assertions.assertEquals("jksb", model.folder().name());
+ Assertions.assertEquals("grdspzesfkqq", model.description());
+ Assertions.assertEquals("j", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("yftgpqoswgfqv").type());
+ Assertions.assertEquals("l", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTypePropertiesTests.java
index 6057846ae260..9b663d95f659 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreDatasetTypePropertiesTests.java
@@ -15,20 +15,20 @@ public final class AzureDataLakeStoreDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataLakeStoreDatasetTypeProperties model = BinaryData.fromString(
- "{\"folderPath\":\"datarsnqpljpetex\",\"fileName\":\"dataikelpmwgr\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datawu\",\"deserializer\":\"datavosgjzscu\",\"\":{\"j\":\"datalivdfwg\",\"zkhzpriqi\":\"dataewcffrxgg\",\"syzaivnp\":\"datasenerr\",\"kplujyduon\":\"datajnp\"}},\"compression\":{\"type\":\"dataawsaoplvvmnbkx\",\"level\":\"datarsbbd\",\"\":{\"qk\":\"dataokqxail\",\"rdspzesfkqqxu\":\"datayqjvzvc\",\"xa\":\"datavzflbrous\"}}}")
+ "{\"folderPath\":\"dataxhklsqxt\",\"fileName\":\"datayygktsrjyxxoxwf\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datavecnxfxphs\",\"deserializer\":\"databebsnbw\",\"\":{\"fjajvkyxmm\":\"datavuwmsumustihtgr\",\"rjenn\":\"dataczvogtd\",\"phfxnrpdhewoky\":\"datakvaeuwqdwxhhlbm\"}},\"compression\":{\"type\":\"datafkxfsywbihqb\",\"level\":\"datadjfyxbvkv\",\"\":{\"wnjdvvlrh\":\"datamvddqwcrugyozzz\"}}}")
.toObject(AzureDataLakeStoreDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDataLakeStoreDatasetTypeProperties model
- = new AzureDataLakeStoreDatasetTypeProperties().withFolderPath("datarsnqpljpetex")
- .withFileName("dataikelpmwgr")
- .withFormat(new DatasetStorageFormat().withSerializer("datawu")
- .withDeserializer("datavosgjzscu")
+ = new AzureDataLakeStoreDatasetTypeProperties().withFolderPath("dataxhklsqxt")
+ .withFileName("datayygktsrjyxxoxwf")
+ .withFormat(new DatasetStorageFormat().withSerializer("datavecnxfxphs")
+ .withDeserializer("databebsnbw")
.withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("dataawsaoplvvmnbkx")
- .withLevel("datarsbbd")
+ .withCompression(new DatasetCompression().withType("datafkxfsywbihqb")
+ .withLevel("datadjfyxbvkv")
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(AzureDataLakeStoreDatasetTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreReadSettingsTests.java
index f20c4b8997ac..16186be07a8d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreReadSettingsTests.java
@@ -11,26 +11,26 @@ public final class AzureDataLakeStoreReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataLakeStoreReadSettings model = BinaryData.fromString(
- "{\"type\":\"AzureDataLakeStoreReadSettings\",\"recursive\":\"datayosig\",\"wildcardFolderPath\":\"datanykjxq\",\"wildcardFileName\":\"datapeqgedpizjqp\",\"fileListPath\":\"dataturdiv\",\"listAfter\":\"datakwma\",\"listBefore\":\"dataxoqakvutedet\",\"enablePartitionDiscovery\":\"datakqud\",\"partitionRootPath\":\"datawcwjacdbkcehxahn\",\"deleteFilesAfterCompletion\":\"databav\",\"modifiedDatetimeStart\":\"datalfefbbv\",\"modifiedDatetimeEnd\":\"datalnnpafufwrerbnd\",\"maxConcurrentConnections\":\"datazfnstlavmdc\",\"disableMetricsCollection\":\"dataemvaajyitpyz\",\"\":{\"hvbvjyfdwaupjozg\":\"datahkswurzaqubr\",\"mxznfoa\":\"datayocgwkphilyznbbc\",\"ei\":\"datasjwiswznlbbht\",\"sazgnyf\":\"datafizbehvqaghltn\"}}")
+ "{\"type\":\"AzureDataLakeStoreReadSettings\",\"recursive\":\"datanhvdkqigppdqsqs\",\"wildcardFolderPath\":\"dataweaxthuhuruo\",\"wildcardFileName\":\"datayotapstkdbn\",\"fileListPath\":\"datapcuzexoymfku\",\"listAfter\":\"dataysgsqzpgrvf\",\"listBefore\":\"datayph\",\"enablePartitionDiscovery\":\"datarxrpahp\",\"partitionRootPath\":\"dataikfenmiflkyf\",\"deleteFilesAfterCompletion\":\"datalolnxhsupilh\",\"modifiedDatetimeStart\":\"dataabli\",\"modifiedDatetimeEnd\":\"dataoomgsejisydh\",\"maxConcurrentConnections\":\"datadxnkluqf\",\"disableMetricsCollection\":\"dataglftlqakie\",\"\":{\"xewcscuveljfarin\":\"datavprb\"}}")
.toObject(AzureDataLakeStoreReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDataLakeStoreReadSettings model
- = new AzureDataLakeStoreReadSettings().withMaxConcurrentConnections("datazfnstlavmdc")
- .withDisableMetricsCollection("dataemvaajyitpyz")
- .withRecursive("datayosig")
- .withWildcardFolderPath("datanykjxq")
- .withWildcardFileName("datapeqgedpizjqp")
- .withFileListPath("dataturdiv")
- .withListAfter("datakwma")
- .withListBefore("dataxoqakvutedet")
- .withEnablePartitionDiscovery("datakqud")
- .withPartitionRootPath("datawcwjacdbkcehxahn")
- .withDeleteFilesAfterCompletion("databav")
- .withModifiedDatetimeStart("datalfefbbv")
- .withModifiedDatetimeEnd("datalnnpafufwrerbnd");
+ = new AzureDataLakeStoreReadSettings().withMaxConcurrentConnections("datadxnkluqf")
+ .withDisableMetricsCollection("dataglftlqakie")
+ .withRecursive("datanhvdkqigppdqsqs")
+ .withWildcardFolderPath("dataweaxthuhuruo")
+ .withWildcardFileName("datayotapstkdbn")
+ .withFileListPath("datapcuzexoymfku")
+ .withListAfter("dataysgsqzpgrvf")
+ .withListBefore("datayph")
+ .withEnablePartitionDiscovery("datarxrpahp")
+ .withPartitionRootPath("dataikfenmiflkyf")
+ .withDeleteFilesAfterCompletion("datalolnxhsupilh")
+ .withModifiedDatetimeStart("dataabli")
+ .withModifiedDatetimeEnd("dataoomgsejisydh");
model = BinaryData.fromObject(model).toObject(AzureDataLakeStoreReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSinkTests.java
index bbc4b888470d..b77355f34ae4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSinkTests.java
@@ -11,20 +11,20 @@ public final class AzureDataLakeStoreSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataLakeStoreSink model = BinaryData.fromString(
- "{\"type\":\"AzureDataLakeStoreSink\",\"copyBehavior\":\"datayxt\",\"enableAdlsSingleFileParallel\":\"datafqqzhq\",\"writeBatchSize\":\"dataoexgnyugsasgheic\",\"writeBatchTimeout\":\"datadxhxpqk\",\"sinkRetryCount\":\"datatynjxfndxrofwc\",\"sinkRetryWait\":\"datahdbidldkti\",\"maxConcurrentConnections\":\"dataitfaekpxvetdr\",\"disableMetricsCollection\":\"datatsorwtaknylxr\",\"\":{\"k\":\"dataoskwujhskxx\"}}")
+ "{\"type\":\"AzureDataLakeStoreSink\",\"copyBehavior\":\"datandfrfhgowhnvc\",\"enableAdlsSingleFileParallel\":\"datamuvgysto\",\"writeBatchSize\":\"datarktodeertyijlvcm\",\"writeBatchTimeout\":\"datanxxw\",\"sinkRetryCount\":\"dataedbdkwzbkhvlsahj\",\"sinkRetryWait\":\"databwyqnlus\",\"maxConcurrentConnections\":\"datalkrcpxlk\",\"disableMetricsCollection\":\"datafxtbvhmsvcmce\",\"\":{\"gkrpjonminsqjnu\":\"datahwriihwxchyy\",\"gkkg\":\"dataiytyarpeyigfdp\",\"bgrtse\":\"dataygjldljgd\",\"kofmtfwculsbnapz\":\"datanowzf\"}}")
.toObject(AzureDataLakeStoreSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDataLakeStoreSink model = new AzureDataLakeStoreSink().withWriteBatchSize("dataoexgnyugsasgheic")
- .withWriteBatchTimeout("datadxhxpqk")
- .withSinkRetryCount("datatynjxfndxrofwc")
- .withSinkRetryWait("datahdbidldkti")
- .withMaxConcurrentConnections("dataitfaekpxvetdr")
- .withDisableMetricsCollection("datatsorwtaknylxr")
- .withCopyBehavior("datayxt")
- .withEnableAdlsSingleFileParallel("datafqqzhq");
+ AzureDataLakeStoreSink model = new AzureDataLakeStoreSink().withWriteBatchSize("datarktodeertyijlvcm")
+ .withWriteBatchTimeout("datanxxw")
+ .withSinkRetryCount("dataedbdkwzbkhvlsahj")
+ .withSinkRetryWait("databwyqnlus")
+ .withMaxConcurrentConnections("datalkrcpxlk")
+ .withDisableMetricsCollection("datafxtbvhmsvcmce")
+ .withCopyBehavior("datandfrfhgowhnvc")
+ .withEnableAdlsSingleFileParallel("datamuvgysto");
model = BinaryData.fromObject(model).toObject(AzureDataLakeStoreSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSourceTests.java
index 217fb5d90dc9..f2e4d70ab8d7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreSourceTests.java
@@ -11,17 +11,17 @@ public final class AzureDataLakeStoreSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataLakeStoreSource model = BinaryData.fromString(
- "{\"type\":\"AzureDataLakeStoreSource\",\"recursive\":\"datahrygw\",\"sourceRetryCount\":\"datavuiox\",\"sourceRetryWait\":\"dataztrfot\",\"maxConcurrentConnections\":\"datafzcvhfnbccffsb\",\"disableMetricsCollection\":\"databt\",\"\":{\"j\":\"datal\",\"chpzv\":\"dataoudjcttav\",\"lferjwhonn\":\"dataz\"}}")
+ "{\"type\":\"AzureDataLakeStoreSource\",\"recursive\":\"datazythxzrvjfsmfkd\",\"sourceRetryCount\":\"datawfrmhookef\",\"sourceRetryWait\":\"datafexakctlcps\",\"maxConcurrentConnections\":\"datancco\",\"disableMetricsCollection\":\"dataqxmdievkmrso\",\"\":{\"imuqqmdxcwx\":\"dataiheh\",\"ypsypmthf\":\"datamrmwd\",\"afcxdldh\":\"datasz\",\"urhsmg\":\"datakdeviwpzhfxvlc\"}}")
.toObject(AzureDataLakeStoreSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDataLakeStoreSource model = new AzureDataLakeStoreSource().withSourceRetryCount("datavuiox")
- .withSourceRetryWait("dataztrfot")
- .withMaxConcurrentConnections("datafzcvhfnbccffsb")
- .withDisableMetricsCollection("databt")
- .withRecursive("datahrygw");
+ AzureDataLakeStoreSource model = new AzureDataLakeStoreSource().withSourceRetryCount("datawfrmhookef")
+ .withSourceRetryWait("datafexakctlcps")
+ .withMaxConcurrentConnections("datancco")
+ .withDisableMetricsCollection("dataqxmdievkmrso")
+ .withRecursive("datazythxzrvjfsmfkd");
model = BinaryData.fromObject(model).toObject(AzureDataLakeStoreSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreWriteSettingsTests.java
index fa01b9e70018..c25ed234ce3b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDataLakeStoreWriteSettingsTests.java
@@ -13,19 +13,18 @@ public final class AzureDataLakeStoreWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDataLakeStoreWriteSettings model = BinaryData.fromString(
- "{\"type\":\"AzureDataLakeStoreWriteSettings\",\"expiryDateTime\":\"datajbdyyxhj\",\"maxConcurrentConnections\":\"datajb\",\"disableMetricsCollection\":\"datardlnbklh\",\"copyBehavior\":\"dataikruljbhgzff\",\"metadata\":[{\"name\":\"dataoiaobbzcdlcc\",\"value\":\"datamvbhb\"},{\"name\":\"dataibxolzinxxjfixr\",\"value\":\"datawxcaa\"}],\"\":{\"hacfiyrywfry\":\"dataqosgzgsgzlbunm\",\"iiarlldy\":\"datarreebjmslbxf\",\"wuebrvrh\":\"datafjdtykhsafrf\",\"ybwh\":\"dataqkfffvgbklei\"}}")
+ "{\"type\":\"AzureDataLakeStoreWriteSettings\",\"expiryDateTime\":\"databyul\",\"maxConcurrentConnections\":\"dataepssoqdibyg\",\"disableMetricsCollection\":\"datacidiwkxi\",\"copyBehavior\":\"dataiqxlxoksyypftrdi\",\"metadata\":[{\"name\":\"databqgatkl\",\"value\":\"datapgwp\"}],\"\":{\"nsdp\":\"dataccetyyvxkwobb\",\"lzk\":\"datairt\"}}")
.toObject(AzureDataLakeStoreWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDataLakeStoreWriteSettings model
- = new AzureDataLakeStoreWriteSettings().withMaxConcurrentConnections("datajb")
- .withDisableMetricsCollection("datardlnbklh")
- .withCopyBehavior("dataikruljbhgzff")
- .withMetadata(Arrays.asList(new MetadataItem().withName("dataoiaobbzcdlcc").withValue("datamvbhb"),
- new MetadataItem().withName("dataibxolzinxxjfixr").withValue("datawxcaa")))
- .withExpiryDateTime("datajbdyyxhj");
+ = new AzureDataLakeStoreWriteSettings().withMaxConcurrentConnections("dataepssoqdibyg")
+ .withDisableMetricsCollection("datacidiwkxi")
+ .withCopyBehavior("dataiqxlxoksyypftrdi")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("databqgatkl").withValue("datapgwp")))
+ .withExpiryDateTime("databyul");
model = BinaryData.fromObject(model).toObject(AzureDataLakeStoreWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTests.java
index 751d701665b3..680823b490c4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTests.java
@@ -19,35 +19,35 @@ public final class AzureDatabricksDeltaLakeDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDatabricksDeltaLakeDataset model = BinaryData.fromString(
- "{\"type\":\"AzureDatabricksDeltaLakeDataset\",\"typeProperties\":{\"table\":\"dataram\",\"database\":\"dataugqcglmadfztof\"},\"description\":\"qlauuagwayf\",\"structure\":\"datae\",\"schema\":\"dataxfei\",\"linkedServiceName\":{\"referenceName\":\"basthz\",\"parameters\":{\"qcj\":\"datapssvnonij\",\"kvocu\":\"datazzjkugpdqqbt\"}},\"parameters\":{\"tt\":{\"type\":\"Bool\",\"defaultValue\":\"datapwarhw\"},\"tkzbhizxp\":{\"type\":\"Float\",\"defaultValue\":\"datapzwxy\"},\"ushvlxudhe\":{\"type\":\"Int\",\"defaultValue\":\"datadmwnfhmjusuqn\"},\"sz\":{\"type\":\"Array\",\"defaultValue\":\"datanirmidtvhjc\"}},\"annotations\":[\"dataygkxrlfojlclp\",\"datamveybodhrv\"],\"folder\":{\"name\":\"u\"},\"\":{\"gpdxtsaujtco\":\"databcumjv\",\"l\":\"datajybolqoxupt\",\"vamtyk\":\"dataivmlkwkzli\",\"fxcsqmzdozktkdpc\":\"dataszde\"}}")
+ "{\"type\":\"AzureDatabricksDeltaLakeDataset\",\"typeProperties\":{\"table\":\"datal\",\"database\":\"datacf\"},\"description\":\"rn\",\"structure\":\"dataqpkayqivbigdrqg\",\"schema\":\"datatboyztgnmu\",\"linkedServiceName\":{\"referenceName\":\"ppwp\",\"parameters\":{\"ofeiiewibdtplj\":\"datagrmtgwhzbbdwrjen\"}},\"parameters\":{\"xjwtkftgzljue\":{\"type\":\"Object\",\"defaultValue\":\"dataokbxxcdk\"},\"lb\":{\"type\":\"Int\",\"defaultValue\":\"datawsjpgb\"},\"epvrunudma\":{\"type\":\"Object\",\"defaultValue\":\"datagv\"},\"kwohdig\":{\"type\":\"Int\",\"defaultValue\":\"datahrnaxkc\"}},\"annotations\":[\"dataocft\",\"dataamodw\"],\"folder\":{\"name\":\"ktvxerow\"},\"\":{\"xgd\":\"datarnnbegrafeonmto\",\"aq\":\"datafmazhkqqsjk\",\"evveswghhbqqhd\":\"datazbwgpmdmwi\"}}")
.toObject(AzureDatabricksDeltaLakeDataset.class);
- Assertions.assertEquals("qlauuagwayf", model.description());
- Assertions.assertEquals("basthz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("tt").type());
- Assertions.assertEquals("u", model.folder().name());
+ Assertions.assertEquals("rn", model.description());
+ Assertions.assertEquals("ppwp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xjwtkftgzljue").type());
+ Assertions.assertEquals("ktvxerow", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDatabricksDeltaLakeDataset model = new AzureDatabricksDeltaLakeDataset().withDescription("qlauuagwayf")
- .withStructure("datae")
- .withSchema("dataxfei")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("basthz")
- .withParameters(mapOf("qcj", "datapssvnonij", "kvocu", "datazzjkugpdqqbt")))
- .withParameters(mapOf("tt",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datapwarhw"), "tkzbhizxp",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datapzwxy"), "ushvlxudhe",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datadmwnfhmjusuqn"), "sz",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanirmidtvhjc")))
- .withAnnotations(Arrays.asList("dataygkxrlfojlclp", "datamveybodhrv"))
- .withFolder(new DatasetFolder().withName("u"))
- .withTable("dataram")
- .withDatabase("dataugqcglmadfztof");
+ AzureDatabricksDeltaLakeDataset model = new AzureDatabricksDeltaLakeDataset().withDescription("rn")
+ .withStructure("dataqpkayqivbigdrqg")
+ .withSchema("datatboyztgnmu")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ppwp")
+ .withParameters(mapOf("ofeiiewibdtplj", "datagrmtgwhzbbdwrjen")))
+ .withParameters(mapOf("xjwtkftgzljue",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataokbxxcdk"), "lb",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datawsjpgb"), "epvrunudma",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datagv"), "kwohdig",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datahrnaxkc")))
+ .withAnnotations(Arrays.asList("dataocft", "dataamodw"))
+ .withFolder(new DatasetFolder().withName("ktvxerow"))
+ .withTable("datal")
+ .withDatabase("datacf");
model = BinaryData.fromObject(model).toObject(AzureDatabricksDeltaLakeDataset.class);
- Assertions.assertEquals("qlauuagwayf", model.description());
- Assertions.assertEquals("basthz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("tt").type());
- Assertions.assertEquals("u", model.folder().name());
+ Assertions.assertEquals("rn", model.description());
+ Assertions.assertEquals("ppwp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xjwtkftgzljue").type());
+ Assertions.assertEquals("ktvxerow", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTypePropertiesTests.java
index 99c9090151de..cab06036c8e6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeDatasetTypePropertiesTests.java
@@ -11,15 +11,15 @@ public final class AzureDatabricksDeltaLakeDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDatabricksDeltaLakeDatasetTypeProperties model
- = BinaryData.fromString("{\"table\":\"dataohplrgcnbvmhvq\",\"database\":\"dataedaxkuyorfjidqo\"}")
+ = BinaryData.fromString("{\"table\":\"dataargkwimtc\",\"database\":\"dataeeuquuwczzcujwx\"}")
.toObject(AzureDatabricksDeltaLakeDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDatabricksDeltaLakeDatasetTypeProperties model
- = new AzureDatabricksDeltaLakeDatasetTypeProperties().withTable("dataohplrgcnbvmhvq")
- .withDatabase("dataedaxkuyorfjidqo");
+ = new AzureDatabricksDeltaLakeDatasetTypeProperties().withTable("dataargkwimtc")
+ .withDatabase("dataeeuquuwczzcujwx");
model = BinaryData.fromObject(model).toObject(AzureDatabricksDeltaLakeDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeExportCommandTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeExportCommandTests.java
index 9743a4f051ff..c6b70df62288 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeExportCommandTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeExportCommandTests.java
@@ -11,15 +11,15 @@ public final class AzureDatabricksDeltaLakeExportCommandTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDatabricksDeltaLakeExportCommand model = BinaryData.fromString(
- "{\"type\":\"AzureDatabricksDeltaLakeExportCommand\",\"dateFormat\":\"datasj\",\"timestampFormat\":\"dataxedzmmcgqifh\",\"\":{\"rvh\":\"dataugwkqnmhfmll\",\"mcrcel\":\"datahxcrweeqkdmp\",\"ntwikmgwxysuts\":\"datanjftnfdcjtvei\"}}")
+ "{\"type\":\"AzureDatabricksDeltaLakeExportCommand\",\"dateFormat\":\"dataioqwmhcpujygnt\",\"timestampFormat\":\"datae\",\"\":{\"rso\":\"datasqthcywyoqx\",\"lr\":\"dataf\",\"ffl\":\"dataj\",\"ljf\":\"datazm\"}}")
.toObject(AzureDatabricksDeltaLakeExportCommand.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDatabricksDeltaLakeExportCommand model
- = new AzureDatabricksDeltaLakeExportCommand().withDateFormat("datasj")
- .withTimestampFormat("dataxedzmmcgqifh");
+ = new AzureDatabricksDeltaLakeExportCommand().withDateFormat("dataioqwmhcpujygnt")
+ .withTimestampFormat("datae");
model = BinaryData.fromObject(model).toObject(AzureDatabricksDeltaLakeExportCommand.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeImportCommandTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeImportCommandTests.java
index f543aa37ebbc..42fe016597a4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeImportCommandTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeImportCommandTests.java
@@ -11,15 +11,14 @@ public final class AzureDatabricksDeltaLakeImportCommandTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDatabricksDeltaLakeImportCommand model = BinaryData.fromString(
- "{\"type\":\"AzureDatabricksDeltaLakeImportCommand\",\"dateFormat\":\"dataaezkbrvtaul\",\"timestampFormat\":\"dataqvtpkodijcn\",\"\":{\"hijbfiyuho\":\"datayqvcyqjj\"}}")
+ "{\"type\":\"AzureDatabricksDeltaLakeImportCommand\",\"dateFormat\":\"datardb\",\"timestampFormat\":\"dataqtxpf\",\"\":{\"kqscmdsjgows\":\"datafvhbbnoevkkrlkdo\",\"peqlhhmbyfacexp\":\"datalgu\",\"pkqiqs\":\"datapqykicesqpvmoxil\"}}")
.toObject(AzureDatabricksDeltaLakeImportCommand.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureDatabricksDeltaLakeImportCommand model
- = new AzureDatabricksDeltaLakeImportCommand().withDateFormat("dataaezkbrvtaul")
- .withTimestampFormat("dataqvtpkodijcn");
+ = new AzureDatabricksDeltaLakeImportCommand().withDateFormat("datardb").withTimestampFormat("dataqtxpf");
model = BinaryData.fromObject(model).toObject(AzureDatabricksDeltaLakeImportCommand.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSinkTests.java
index 80fcf5d7507b..165b86b5a013 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSinkTests.java
@@ -12,21 +12,22 @@ public final class AzureDatabricksDeltaLakeSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDatabricksDeltaLakeSink model = BinaryData.fromString(
- "{\"type\":\"AzureDatabricksDeltaLakeSink\",\"preCopyScript\":\"datadhr\",\"importSettings\":{\"type\":\"AzureDatabricksDeltaLakeImportCommand\",\"dateFormat\":\"datakstrmsbmdgrzke\",\"timestampFormat\":\"datalorntnssma\",\"\":{\"htbjyycacoelv\":\"datacdlnvupiscbz\",\"ry\":\"datayltmxqalq\",\"gdubwmalt\":\"datajwwoxanefellhdsg\"}},\"writeBatchSize\":\"databvuv\",\"writeBatchTimeout\":\"datapylphnaghglaxjm\",\"sinkRetryCount\":\"datam\",\"sinkRetryWait\":\"dataloqatswvt\",\"maxConcurrentConnections\":\"datapicwnbtvlrs\",\"disableMetricsCollection\":\"datatrmodknxerkaiik\",\"\":{\"qrkeyh\":\"dataaqx\"}}")
+ "{\"type\":\"AzureDatabricksDeltaLakeSink\",\"preCopyScript\":\"datalwlzekygnep\",\"importSettings\":{\"type\":\"AzureDatabricksDeltaLakeImportCommand\",\"dateFormat\":\"dataxqdrphiyxjq\",\"timestampFormat\":\"datanpztlac\",\"\":{\"ovvyhsorcavkfh\":\"datazsfutaapbrwv\"}},\"writeBatchSize\":\"dataigzwedfteratvpk\",\"writeBatchTimeout\":\"datawrmujizdmh\",\"sinkRetryCount\":\"datafjdiwzgwmumuc\",\"sinkRetryWait\":\"dataq\",\"maxConcurrentConnections\":\"datascva\",\"disableMetricsCollection\":\"dataxgelnjgftqkgavgo\",\"\":{\"krastbkskk\":\"dataxpay\",\"dfmplgdxdt\":\"dataiebmwy\"}}")
.toObject(AzureDatabricksDeltaLakeSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDatabricksDeltaLakeSink model = new AzureDatabricksDeltaLakeSink().withWriteBatchSize("databvuv")
- .withWriteBatchTimeout("datapylphnaghglaxjm")
- .withSinkRetryCount("datam")
- .withSinkRetryWait("dataloqatswvt")
- .withMaxConcurrentConnections("datapicwnbtvlrs")
- .withDisableMetricsCollection("datatrmodknxerkaiik")
- .withPreCopyScript("datadhr")
- .withImportSettings(new AzureDatabricksDeltaLakeImportCommand().withDateFormat("datakstrmsbmdgrzke")
- .withTimestampFormat("datalorntnssma"));
+ AzureDatabricksDeltaLakeSink model
+ = new AzureDatabricksDeltaLakeSink().withWriteBatchSize("dataigzwedfteratvpk")
+ .withWriteBatchTimeout("datawrmujizdmh")
+ .withSinkRetryCount("datafjdiwzgwmumuc")
+ .withSinkRetryWait("dataq")
+ .withMaxConcurrentConnections("datascva")
+ .withDisableMetricsCollection("dataxgelnjgftqkgavgo")
+ .withPreCopyScript("datalwlzekygnep")
+ .withImportSettings(new AzureDatabricksDeltaLakeImportCommand().withDateFormat("dataxqdrphiyxjq")
+ .withTimestampFormat("datanpztlac"));
model = BinaryData.fromObject(model).toObject(AzureDatabricksDeltaLakeSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSourceTests.java
index ac8b1c681f7f..c410e3dc217e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureDatabricksDeltaLakeSourceTests.java
@@ -12,19 +12,20 @@ public final class AzureDatabricksDeltaLakeSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureDatabricksDeltaLakeSource model = BinaryData.fromString(
- "{\"type\":\"AzureDatabricksDeltaLakeSource\",\"query\":\"dataffjie\",\"exportSettings\":{\"type\":\"AzureDatabricksDeltaLakeExportCommand\",\"dateFormat\":\"datahsq\",\"timestampFormat\":\"dataswbzh\",\"\":{\"wntghjmmjmmj\":\"dataoayu\"}},\"sourceRetryCount\":\"datahyf\",\"sourceRetryWait\":\"datasemnidbaykvlrs\",\"maxConcurrentConnections\":\"dataniocyo\",\"disableMetricsCollection\":\"dataimbchi\",\"\":{\"cargsxmaw\":\"dataaffsjqnjpcybugoj\",\"dugwddob\":\"datavaagazryyjjwggp\"}}")
+ "{\"type\":\"AzureDatabricksDeltaLakeSource\",\"query\":\"datasteeksb\",\"exportSettings\":{\"type\":\"AzureDatabricksDeltaLakeExportCommand\",\"dateFormat\":\"datav\",\"timestampFormat\":\"dataoibvv\",\"\":{\"tnqdcgobkcebzr\":\"dataljmzpyukrwvvhcgt\",\"mtjsklkw\":\"datapu\"}},\"sourceRetryCount\":\"dataqqiqckmfxldqtman\",\"sourceRetryWait\":\"dataj\",\"maxConcurrentConnections\":\"datamrfq\",\"disableMetricsCollection\":\"datacdpwlezbfgullq\",\"\":{\"gksrorxejf\":\"datajyxcmqc\",\"ray\":\"dataarphltlf\",\"wbkxdhavegy\":\"dataxzdujpuhbaog\",\"pdatvndvwwejvqpw\":\"dataqsmlbzi\"}}")
.toObject(AzureDatabricksDeltaLakeSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureDatabricksDeltaLakeSource model = new AzureDatabricksDeltaLakeSource().withSourceRetryCount("datahyf")
- .withSourceRetryWait("datasemnidbaykvlrs")
- .withMaxConcurrentConnections("dataniocyo")
- .withDisableMetricsCollection("dataimbchi")
- .withQuery("dataffjie")
+ AzureDatabricksDeltaLakeSource model = new AzureDatabricksDeltaLakeSource()
+ .withSourceRetryCount("dataqqiqckmfxldqtman")
+ .withSourceRetryWait("dataj")
+ .withMaxConcurrentConnections("datamrfq")
+ .withDisableMetricsCollection("datacdpwlezbfgullq")
+ .withQuery("datasteeksb")
.withExportSettings(
- new AzureDatabricksDeltaLakeExportCommand().withDateFormat("datahsq").withTimestampFormat("dataswbzh"));
+ new AzureDatabricksDeltaLakeExportCommand().withDateFormat("datav").withTimestampFormat("dataoibvv"));
model = BinaryData.fromObject(model).toObject(AzureDatabricksDeltaLakeSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageReadSettingsTests.java
index f1d71cb6121e..0b7bb158a18a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageReadSettingsTests.java
@@ -11,25 +11,25 @@ public final class AzureFileStorageReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureFileStorageReadSettings model = BinaryData.fromString(
- "{\"type\":\"AzureFileStorageReadSettings\",\"recursive\":\"dataolwfkbdwzvhtg\",\"wildcardFolderPath\":\"dataygaphlwmivaz\",\"wildcardFileName\":\"databzcjmsr\",\"prefix\":\"datajbyyxkcva\",\"fileListPath\":\"databysxtjivw\",\"enablePartitionDiscovery\":\"datang\",\"partitionRootPath\":\"datayct\",\"deleteFilesAfterCompletion\":\"datahgjyholsmahbjc\",\"modifiedDatetimeStart\":\"dataskqxgbigozrvlkla\",\"modifiedDatetimeEnd\":\"datalysse\",\"maxConcurrentConnections\":\"datappgsfj\",\"disableMetricsCollection\":\"datagmogmcjn\",\"\":{\"wy\":\"datak\",\"rizflwlkov\":\"datacvqfzvyoxg\",\"dp\":\"datapqpf\"}}")
+ "{\"type\":\"AzureFileStorageReadSettings\",\"recursive\":\"datadqgy\",\"wildcardFolderPath\":\"dataulzguvckpdp\",\"wildcardFileName\":\"datanrjqskikqd\",\"prefix\":\"dataybqtlvofjjsetiz\",\"fileListPath\":\"datanadn\",\"enablePartitionDiscovery\":\"datasbpxlserqgxnh\",\"partitionRootPath\":\"dataccd\",\"deleteFilesAfterCompletion\":\"dataxybn\",\"modifiedDatetimeStart\":\"datahmpmeglolpot\",\"modifiedDatetimeEnd\":\"datamb\",\"maxConcurrentConnections\":\"dataqjrytymfnojjh\",\"disableMetricsCollection\":\"datanthjqgovviv\",\"\":{\"rafet\":\"datay\",\"vpiilgy\":\"datawyt\",\"vpbuk\":\"dataluolgspyqsapnh\",\"oujtcp\":\"dataurqviyfksegwezgf\"}}")
.toObject(AzureFileStorageReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureFileStorageReadSettings model
- = new AzureFileStorageReadSettings().withMaxConcurrentConnections("datappgsfj")
- .withDisableMetricsCollection("datagmogmcjn")
- .withRecursive("dataolwfkbdwzvhtg")
- .withWildcardFolderPath("dataygaphlwmivaz")
- .withWildcardFileName("databzcjmsr")
- .withPrefix("datajbyyxkcva")
- .withFileListPath("databysxtjivw")
- .withEnablePartitionDiscovery("datang")
- .withPartitionRootPath("datayct")
- .withDeleteFilesAfterCompletion("datahgjyholsmahbjc")
- .withModifiedDatetimeStart("dataskqxgbigozrvlkla")
- .withModifiedDatetimeEnd("datalysse");
+ = new AzureFileStorageReadSettings().withMaxConcurrentConnections("dataqjrytymfnojjh")
+ .withDisableMetricsCollection("datanthjqgovviv")
+ .withRecursive("datadqgy")
+ .withWildcardFolderPath("dataulzguvckpdp")
+ .withWildcardFileName("datanrjqskikqd")
+ .withPrefix("dataybqtlvofjjsetiz")
+ .withFileListPath("datanadn")
+ .withEnablePartitionDiscovery("datasbpxlserqgxnh")
+ .withPartitionRootPath("dataccd")
+ .withDeleteFilesAfterCompletion("dataxybn")
+ .withModifiedDatetimeStart("datahmpmeglolpot")
+ .withModifiedDatetimeEnd("datamb");
model = BinaryData.fromObject(model).toObject(AzureFileStorageReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageWriteSettingsTests.java
index b51537830007..8ed38f9e5d8f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFileStorageWriteSettingsTests.java
@@ -13,19 +13,17 @@ public final class AzureFileStorageWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureFileStorageWriteSettings model = BinaryData.fromString(
- "{\"type\":\"AzureFileStorageWriteSettings\",\"maxConcurrentConnections\":\"datasqlyahlaoqkcit\",\"disableMetricsCollection\":\"datauzvaxltrznwh\",\"copyBehavior\":\"datatsauvprqzpfpbx\",\"metadata\":[{\"name\":\"datakkoyzsy\",\"value\":\"datakcld\"},{\"name\":\"dataseka\",\"value\":\"datae\"},{\"name\":\"datalpch\",\"value\":\"datazqmdxmyfrmfclkyn\"}],\"\":{\"zcbohbb\":\"dataaf\",\"c\":\"datavoderduabqbverb\",\"pc\":\"dataszbvhxnjor\",\"uknnm\":\"dataxdlp\"}}")
+ "{\"type\":\"AzureFileStorageWriteSettings\",\"maxConcurrentConnections\":\"dataduttqjtszqexc\",\"disableMetricsCollection\":\"datawbxx\",\"copyBehavior\":\"datavekqjdrumlvk\",\"metadata\":[{\"name\":\"datahhlfvmw\",\"value\":\"dataarswsvtzotmwxq\"}],\"\":{\"wrtmjskb\":\"datadanfexlawkeqjhz\",\"mvounbyvsfqu\":\"dataenjnady\",\"xqbknoxjhedwh\":\"datar\",\"rpajbiig\":\"datamwb\"}}")
.toObject(AzureFileStorageWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureFileStorageWriteSettings model
- = new AzureFileStorageWriteSettings().withMaxConcurrentConnections("datasqlyahlaoqkcit")
- .withDisableMetricsCollection("datauzvaxltrznwh")
- .withCopyBehavior("datatsauvprqzpfpbx")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datakkoyzsy").withValue("datakcld"),
- new MetadataItem().withName("dataseka").withValue("datae"),
- new MetadataItem().withName("datalpch").withValue("datazqmdxmyfrmfclkyn")));
+ AzureFileStorageWriteSettings model = new AzureFileStorageWriteSettings()
+ .withMaxConcurrentConnections("dataduttqjtszqexc")
+ .withDisableMetricsCollection("datawbxx")
+ .withCopyBehavior("datavekqjdrumlvk")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datahhlfvmw").withValue("dataarswsvtzotmwxq")));
model = BinaryData.fromObject(model).toObject(AzureFileStorageWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTests.java
index e2cb5155643f..004d854c7db4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTests.java
@@ -23,72 +23,71 @@ public final class AzureFunctionActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureFunctionActivity model = BinaryData.fromString(
- "{\"type\":\"AzureFunctionActivity\",\"typeProperties\":{\"method\":\"HEAD\",\"functionName\":\"datahwybbdaedqttzslt\",\"headers\":{\"ieaum\":\"datadacetjmap\",\"lhfxjcq\":\"datajxdirdcxuiamr\",\"xqpemqogto\":\"datafpwjjtdzfyivv\"},\"body\":\"datafvysvudbj\"},\"linkedServiceName\":{\"referenceName\":\"htxvmnyslpdq\",\"parameters\":{\"pblnervtym\":\"dataj\"}},\"policy\":{\"timeout\":\"datanjxvtvyyasil\",\"retry\":\"dataqygn\",\"retryIntervalInSeconds\":99436162,\"secureInput\":true,\"secureOutput\":false,\"\":{\"jsugkdv\":\"datavjhmqpjbk\",\"efdsgfztmhvu\":\"datagpeitfbgyznsh\"}},\"name\":\"avpoookhc\",\"description\":\"wgbjzznmjwqwyhh\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"jtfnjrrx\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Failed\",\"Succeeded\"],\"\":{\"uhywdckvcof\":\"dataxnbbsjgvalowmmh\",\"vtakijwkwed\":\"datatceehqeahlfujp\"}},{\"activity\":\"uumldunalo\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"ucdvhqec\":\"dataqcbeunss\",\"uiuzsnjjgnmpuqsj\":\"dataqiulwfzoszgbgtwa\"}},{\"activity\":\"vdaj\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Completed\"],\"\":{\"jzleeup\":\"datamtwtbrpdtbgkxzx\"}},{\"activity\":\"lszcwomayr\",\"dependencyConditions\":[\"Failed\",\"Failed\"],\"\":{\"tiwinnhowih\":\"dataardfxn\",\"dzgmfnpel\":\"datag\"}}],\"userProperties\":[{\"name\":\"sicpxu\",\"value\":\"dataupngorwvayrgu\"},{\"name\":\"fjjg\",\"value\":\"dataf\"},{\"name\":\"fwgrubofhkbjgx\",\"value\":\"datarppxjnrujdskkkzq\"}],\"\":{\"jirhaqe\":\"dataib\",\"xzha\":\"datafuazdak\",\"jfrpbdxsjceyyebg\":\"datacwhjv\",\"vwhqct\":\"dataffntrb\"}}")
+ "{\"type\":\"AzureFunctionActivity\",\"typeProperties\":{\"method\":\"POST\",\"functionName\":\"datanyehh\",\"headers\":{\"ka\":\"datajrmxazkqiqzaea\",\"xivhozhr\":\"datapokf\"},\"body\":\"datavfljxljgtirnpazr\"},\"linkedServiceName\":{\"referenceName\":\"hyzufkzqtv\",\"parameters\":{\"ahdkeayu\":\"datayzihuupeflkwbvxn\"}},\"policy\":{\"timeout\":\"datavpnemydntupbrv\",\"retry\":\"datatblxa\",\"retryIntervalInSeconds\":1508140667,\"secureInput\":true,\"secureOutput\":true,\"\":{\"lsnkwullvukwy\":\"dataxuaidrbz\",\"andjjqhinsv\":\"dataosjz\",\"jrotqdi\":\"dataou\",\"jqkg\":\"dataxffiwrfocbetl\"}},\"name\":\"rvjawaxv\",\"description\":\"jlcj\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"e\",\"dependencyConditions\":[\"Completed\"],\"\":{\"zbjieeivdrqtlcx\":\"datac\"}},{\"activity\":\"ogykrmf\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Completed\"],\"\":{\"mgberxnlj\":\"datavgroewhsnpcwy\"}},{\"activity\":\"vujsnzuebyznkdb\",\"dependencyConditions\":[\"Completed\"],\"\":{\"gksfjqfeeqh\":\"datamnztzhqs\",\"rbdtlikba\":\"datacwrrne\"}},{\"activity\":\"mrqponu\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Failed\",\"Succeeded\"],\"\":{\"vvggvnqpar\":\"dataxps\"}}],\"userProperties\":[{\"name\":\"gdkovytjsrboqamq\",\"value\":\"dataqvukjtcdppdmm\"},{\"name\":\"dubccclt\",\"value\":\"datagx\"}],\"\":{\"kvydvdj\":\"dataiix\",\"yswlmxepygkfuwgk\":\"datagdharlrfay\"}}")
.toObject(AzureFunctionActivity.class);
- Assertions.assertEquals("avpoookhc", model.name());
- Assertions.assertEquals("wgbjzznmjwqwyhh", model.description());
+ Assertions.assertEquals("rvjawaxv", model.name());
+ Assertions.assertEquals("jlcj", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("jtfnjrrx", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("sicpxu", model.userProperties().get(0).name());
- Assertions.assertEquals("htxvmnyslpdq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(99436162, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("e", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("gdkovytjsrboqamq", model.userProperties().get(0).name());
+ Assertions.assertEquals("hyzufkzqtv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1508140667, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(AzureFunctionActivityMethod.HEAD, model.method());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(AzureFunctionActivityMethod.POST, model.method());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureFunctionActivity model = new AzureFunctionActivity().withName("avpoookhc")
- .withDescription("wgbjzznmjwqwyhh")
+ AzureFunctionActivity model = new AzureFunctionActivity().withName("rvjawaxv")
+ .withDescription("jlcj")
.withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("jtfnjrrx")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED,
- DependencyCondition.FAILED, DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("e")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("uumldunalo")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("ogykrmf")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("vdaj")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED,
- DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("vujsnzuebyznkdb")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("lszcwomayr")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("mrqponu")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.FAILED, DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("sicpxu").withValue("dataupngorwvayrgu"),
- new UserProperty().withName("fjjg").withValue("dataf"),
- new UserProperty().withName("fwgrubofhkbjgx").withValue("datarppxjnrujdskkkzq")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("htxvmnyslpdq")
- .withParameters(mapOf("pblnervtym", "dataj")))
- .withPolicy(new ActivityPolicy().withTimeout("datanjxvtvyyasil")
- .withRetry("dataqygn")
- .withRetryIntervalInSeconds(99436162)
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("gdkovytjsrboqamq").withValue("dataqvukjtcdppdmm"),
+ new UserProperty().withName("dubccclt").withValue("datagx")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hyzufkzqtv")
+ .withParameters(mapOf("ahdkeayu", "datayzihuupeflkwbvxn")))
+ .withPolicy(new ActivityPolicy().withTimeout("datavpnemydntupbrv")
+ .withRetry("datatblxa")
+ .withRetryIntervalInSeconds(1508140667)
.withSecureInput(true)
- .withSecureOutput(false)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withMethod(AzureFunctionActivityMethod.HEAD)
- .withFunctionName("datahwybbdaedqttzslt")
- .withHeaders(
- mapOf("ieaum", "datadacetjmap", "lhfxjcq", "datajxdirdcxuiamr", "xqpemqogto", "datafpwjjtdzfyivv"))
- .withBody("datafvysvudbj");
+ .withMethod(AzureFunctionActivityMethod.POST)
+ .withFunctionName("datanyehh")
+ .withHeaders(mapOf("ka", "datajrmxazkqiqzaea", "xivhozhr", "datapokf"))
+ .withBody("datavfljxljgtirnpazr");
model = BinaryData.fromObject(model).toObject(AzureFunctionActivity.class);
- Assertions.assertEquals("avpoookhc", model.name());
- Assertions.assertEquals("wgbjzznmjwqwyhh", model.description());
+ Assertions.assertEquals("rvjawaxv", model.name());
+ Assertions.assertEquals("jlcj", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("jtfnjrrx", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("sicpxu", model.userProperties().get(0).name());
- Assertions.assertEquals("htxvmnyslpdq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(99436162, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("e", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("gdkovytjsrboqamq", model.userProperties().get(0).name());
+ Assertions.assertEquals("hyzufkzqtv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1508140667, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(AzureFunctionActivityMethod.HEAD, model.method());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(AzureFunctionActivityMethod.POST, model.method());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTypePropertiesTests.java
index 279de508a4cd..723da6f79f02 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureFunctionActivityTypePropertiesTests.java
@@ -15,21 +15,21 @@ public final class AzureFunctionActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureFunctionActivityTypeProperties model = BinaryData.fromString(
- "{\"method\":\"OPTIONS\",\"functionName\":\"datayfugk\",\"headers\":{\"fna\":\"datavevudywnyu\",\"vdslrrtvahi\":\"datanlxwukpqcfkxagti\",\"kekbd\":\"datamzbaqrxzjmxtmedo\"},\"body\":\"datawhuepyrfjzyini\"}")
+ "{\"method\":\"POST\",\"functionName\":\"datajqtk\",\"headers\":{\"kj\":\"datamq\",\"cvmhpueiuhhnexnx\":\"dataczpzwfewbj\",\"lipymnukv\":\"datawafi\",\"liodyuu\":\"datajbxvhu\"},\"body\":\"dataqplj\"}")
.toObject(AzureFunctionActivityTypeProperties.class);
- Assertions.assertEquals(AzureFunctionActivityMethod.OPTIONS, model.method());
+ Assertions.assertEquals(AzureFunctionActivityMethod.POST, model.method());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureFunctionActivityTypeProperties model = new AzureFunctionActivityTypeProperties()
- .withMethod(AzureFunctionActivityMethod.OPTIONS)
- .withFunctionName("datayfugk")
- .withHeaders(
- mapOf("fna", "datavevudywnyu", "vdslrrtvahi", "datanlxwukpqcfkxagti", "kekbd", "datamzbaqrxzjmxtmedo"))
- .withBody("datawhuepyrfjzyini");
+ AzureFunctionActivityTypeProperties model
+ = new AzureFunctionActivityTypeProperties().withMethod(AzureFunctionActivityMethod.POST)
+ .withFunctionName("datajqtk")
+ .withHeaders(mapOf("kj", "datamq", "cvmhpueiuhhnexnx", "dataczpzwfewbj", "lipymnukv", "datawafi",
+ "liodyuu", "datajbxvhu"))
+ .withBody("dataqplj");
model = BinaryData.fromObject(model).toObject(AzureFunctionActivityTypeProperties.class);
- Assertions.assertEquals(AzureFunctionActivityMethod.OPTIONS, model.method());
+ Assertions.assertEquals(AzureFunctionActivityMethod.POST, model.method());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTests.java
index 294e6e17b7dc..793e68ac3b4e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTests.java
@@ -23,94 +23,101 @@ public final class AzureMLBatchExecutionActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMLBatchExecutionActivity model = BinaryData.fromString(
- "{\"type\":\"AzureMLBatchExecution\",\"typeProperties\":{\"globalParameters\":{\"uldjeq\":\"dataibkuuo\",\"mcy\":\"datamo\"},\"webServiceOutputs\":{\"chqigjamozlh\":{\"filePath\":\"datakeuraylygclwbu\",\"linkedServiceName\":{\"referenceName\":\"qamvdnexqvt\",\"parameters\":{\"unoelknyopglgk\":\"datahzgtydll\",\"zoaryhcx\":\"dataazyhhcqjahhc\",\"bdyhjfmyc\":\"dataftgmqlcooyxfrr\",\"yydbxlturlnbmj\":\"dataucccb\"}}},\"b\":{\"filePath\":\"datat\",\"linkedServiceName\":{\"referenceName\":\"tegxnguvjryfcxsc\",\"parameters\":{\"mnfgfsjp\":\"dataytnoiriemkxmvqa\"}}},\"mtahnimkndujyw\":{\"filePath\":\"datasvweu\",\"linkedServiceName\":{\"referenceName\":\"toe\",\"parameters\":{\"wtpvaiewf\":\"datahmrawmchcde\",\"thpg\":\"datawfkw\"}}},\"praaf\":{\"filePath\":\"dataxf\",\"linkedServiceName\":{\"referenceName\":\"lymuwaf\",\"parameters\":{\"sxcd\":\"datatmttjduc\",\"papwmpdsvkiwjbuf\":\"datatovtnfwp\",\"dg\":\"datamlkjfvudigwkyykh\"}}}},\"webServiceInputs\":{\"f\":{\"filePath\":\"dataojt\",\"linkedServiceName\":{\"referenceName\":\"upjgebnsuiklnc\",\"parameters\":{\"fpcvblyeoyn\":\"dataghrbabxywojux\",\"zmfuh\":\"datahxkq\",\"hvmez\":\"dataupifgizkvokkhr\"}}},\"ttdyvifltvwebzf\":{\"filePath\":\"datadrtokw\",\"linkedServiceName\":{\"referenceName\":\"mbonureklgunpajw\",\"parameters\":{\"smookhobzi\":\"datactdpjuwujx\",\"niac\":\"dataqpstxulnntjiucn\"}}},\"ktwk\":{\"filePath\":\"datallk\",\"linkedServiceName\":{\"referenceName\":\"nwinqywlvxuxztj\",\"parameters\":{\"kq\":\"datarqh\",\"lkjhmugyayhpdstl\":\"dataxjly\",\"evrglzx\":\"datadgiqgeeqcgunsoi\",\"daqxnkdqsyhm\":\"datawkkykaz\"}}}}},\"linkedServiceName\":{\"referenceName\":\"vhwkwzxjezys\",\"parameters\":{\"uhydxahjuda\":\"datarhbkzzqwikqkx\",\"dflfx\":\"datammgsxolwofofmyl\",\"cccaujga\":\"datalwhtpyk\",\"vgemblntdynp\":\"datackjqupjxdbgmgx\"}},\"policy\":{\"timeout\":\"dataigxefscsrw\",\"retry\":\"datauteusuxvliq\",\"retryIntervalInSeconds\":1459080325,\"secureInput\":false,\"secureOutput\":false,\"\":{\"gizvvtdrjockz\":\"datazzsbqnv\",\"ppjzmpxam\":\"datafnph\"}},\"name\":\"qdostvx\",\"description\":\"fnmnfndrbkko\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"qfze\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Failed\",\"Failed\"],\"\":{\"kvn\":\"datadr\",\"arvhzfynbxw\":\"datazumczlknfwslvs\"}}],\"userProperties\":[{\"name\":\"mvlkuvbesrawzxnw\",\"value\":\"datasjygi\"}],\"\":{\"slcnsxhpqey\":\"datafo\",\"chdjarfdfnqfvr\":\"datazydpvv\",\"n\":\"dataxlh\"}}")
+ "{\"type\":\"AzureMLBatchExecution\",\"typeProperties\":{\"globalParameters\":{\"hghorgji\":\"datajaktgtwvzp\",\"bqdsuaazkouvvgcw\":\"dataragqcwcdbtopuyi\",\"gaofwo\":\"dataimhjbxwr\",\"xp\":\"dataz\"},\"webServiceOutputs\":{\"euegrdit\":{\"filePath\":\"datax\",\"linkedServiceName\":{\"referenceName\":\"m\",\"parameters\":{\"uxjh\":\"datafsh\",\"uz\":\"datauzirhcghnclfahr\"}}},\"xabtlmszqaudaip\":{\"filePath\":\"dataptpq\",\"linkedServiceName\":{\"referenceName\":\"ajggmmiwoisql\",\"parameters\":{\"cptoihoyvua\":\"datafycnpovnjzaaox\",\"gslqpz\":\"datafju\",\"vfbzzscepo\":\"dataxwdanlgc\",\"yiuhjqdw\":\"datagzppufueiaiece\"}}}},\"webServiceInputs\":{\"qgivyxoj\":{\"filePath\":\"dataxjkopivszejb\",\"linkedServiceName\":{\"referenceName\":\"trmhabzjemqvl\",\"parameters\":{\"cgqh\":\"datacaxnbqsjz\"}}},\"aubhrbtthzfgpzy\":{\"filePath\":\"datamussvurslwd\",\"linkedServiceName\":{\"referenceName\":\"n\",\"parameters\":{\"daql\":\"dataalv\",\"whtws\":\"datasoqrhwla\",\"srvtrwswb\":\"dataliwpzucetzi\"}}},\"dyxjicikzm\":{\"filePath\":\"dataivusehyvqxjbqfcl\",\"linkedServiceName\":{\"referenceName\":\"jecajtuo\",\"parameters\":{\"xn\":\"datalzxuakbavpk\",\"vsgx\":\"datarbckfzb\",\"htlvja\":\"dataijnvsjgnbdhhqs\"}}},\"emsl\":{\"filePath\":\"datadddfjmirbnfc\",\"linkedServiceName\":{\"referenceName\":\"l\",\"parameters\":{\"q\":\"datavpfspfdfrymrf\",\"w\":\"dataxln\",\"qhzotkowi\":\"datagi\",\"wymrmuioepi\":\"datauerhzyl\"}}}}},\"linkedServiceName\":{\"referenceName\":\"tvryszqzvemwne\",\"parameters\":{\"ywdgrskdlt\":\"datawjcgryolbqcft\",\"vmcxljlpyh\":\"datafzyijn\"}},\"policy\":{\"timeout\":\"datadjgcuew\",\"retry\":\"dataqbqgfq\",\"retryIntervalInSeconds\":1286883147,\"secureInput\":true,\"secureOutput\":true,\"\":{\"oubjnmoid\":\"datajmxvvtuk\",\"cgmfklqswwdbs\":\"datanbfbkwyvw\",\"vo\":\"dataghysedqrb\",\"yibycoupksa\":\"dataqrwngfyjfquzxmtm\"}},\"name\":\"djkrosqxvffrn\",\"description\":\"wvjgyjoklngjs\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"sqdnasj\",\"dependencyConditions\":[\"Succeeded\",\"Failed\"],\"\":{\"bvqsl\":\"datakszzbdtvrgy\",\"uqvq\":\"datak\",\"atyqawtfyzqo\":\"dataotvfcbgffdlff\"}},{\"activity\":\"glixhapvwacwrcte\",\"dependencyConditions\":[\"Completed\",\"Skipped\",\"Failed\"],\"\":{\"ble\":\"datazncoxeop\"}},{\"activity\":\"axrsyxeqwgaeice\",\"dependencyConditions\":[\"Completed\"],\"\":{\"cxkywypztssq\":\"dataci\",\"wzwvttkh\":\"dataclaec\",\"qjqjkhqa\":\"dataxqyinfd\"}}],\"userProperties\":[{\"name\":\"czaqgevsnnqvkuf\",\"value\":\"datazwgw\"},{\"name\":\"dv\",\"value\":\"dataskffqqaobbq\"}],\"\":{\"ykhtsycct\":\"datajusqhrvadffdr\",\"siembc\":\"datarvn\",\"ixjkxvz\":\"datatzmldw\",\"orqbmkfo\":\"dataa\"}}")
.toObject(AzureMLBatchExecutionActivity.class);
- Assertions.assertEquals("qdostvx", model.name());
- Assertions.assertEquals("fnmnfndrbkko", model.description());
+ Assertions.assertEquals("djkrosqxvffrn", model.name());
+ Assertions.assertEquals("wvjgyjoklngjs", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("qfze", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("mvlkuvbesrawzxnw", model.userProperties().get(0).name());
- Assertions.assertEquals("vhwkwzxjezys", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1459080325, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("qamvdnexqvt",
- model.webServiceOutputs().get("chqigjamozlh").linkedServiceName().referenceName());
- Assertions.assertEquals("upjgebnsuiklnc",
- model.webServiceInputs().get("f").linkedServiceName().referenceName());
+ Assertions.assertEquals("sqdnasj", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("czaqgevsnnqvkuf", model.userProperties().get(0).name());
+ Assertions.assertEquals("tvryszqzvemwne", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1286883147, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("m", model.webServiceOutputs().get("euegrdit").linkedServiceName().referenceName());
+ Assertions.assertEquals("trmhabzjemqvl",
+ model.webServiceInputs().get("qgivyxoj").linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMLBatchExecutionActivity model = new AzureMLBatchExecutionActivity().withName("qdostvx")
- .withDescription("fnmnfndrbkko")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("qfze")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED,
- DependencyCondition.FAILED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("mvlkuvbesrawzxnw").withValue("datasjygi")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vhwkwzxjezys")
- .withParameters(mapOf("uhydxahjuda", "datarhbkzzqwikqkx", "dflfx", "datammgsxolwofofmyl", "cccaujga",
- "datalwhtpyk", "vgemblntdynp", "datackjqupjxdbgmgx")))
- .withPolicy(new ActivityPolicy().withTimeout("dataigxefscsrw")
- .withRetry("datauteusuxvliq")
- .withRetryIntervalInSeconds(1459080325)
- .withSecureInput(false)
- .withSecureOutput(false)
- .withAdditionalProperties(mapOf()))
- .withGlobalParameters(mapOf("uldjeq", "dataibkuuo", "mcy", "datamo"))
- .withWebServiceOutputs(mapOf("chqigjamozlh",
- new AzureMLWebServiceFile().withFilePath("datakeuraylygclwbu")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qamvdnexqvt")
- .withParameters(mapOf("unoelknyopglgk", "datahzgtydll", "zoaryhcx", "dataazyhhcqjahhc",
- "bdyhjfmyc", "dataftgmqlcooyxfrr", "yydbxlturlnbmj", "dataucccb"))),
- "b",
- new AzureMLWebServiceFile().withFilePath("datat")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tegxnguvjryfcxsc")
- .withParameters(mapOf("mnfgfsjp", "dataytnoiriemkxmvqa"))),
- "mtahnimkndujyw",
- new AzureMLWebServiceFile().withFilePath("datasvweu")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("toe")
- .withParameters(mapOf("wtpvaiewf", "datahmrawmchcde", "thpg", "datawfkw"))),
- "praaf",
- new AzureMLWebServiceFile().withFilePath("dataxf")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lymuwaf")
- .withParameters(mapOf("sxcd", "datatmttjduc", "papwmpdsvkiwjbuf", "datatovtnfwp", "dg",
- "datamlkjfvudigwkyykh")))))
- .withWebServiceInputs(mapOf("f",
- new AzureMLWebServiceFile().withFilePath("dataojt")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("upjgebnsuiklnc")
- .withParameters(mapOf("fpcvblyeoyn", "dataghrbabxywojux", "zmfuh", "datahxkq", "hvmez",
- "dataupifgizkvokkhr"))),
- "ttdyvifltvwebzf",
- new AzureMLWebServiceFile().withFilePath("datadrtokw")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mbonureklgunpajw")
- .withParameters(mapOf("smookhobzi", "datactdpjuwujx", "niac", "dataqpstxulnntjiucn"))),
- "ktwk",
- new AzureMLWebServiceFile().withFilePath("datallk")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("nwinqywlvxuxztj")
- .withParameters(mapOf("kq", "datarqh", "lkjhmugyayhpdstl", "dataxjly", "evrglzx",
- "datadgiqgeeqcgunsoi", "daqxnkdqsyhm", "datawkkykaz")))));
+ AzureMLBatchExecutionActivity model
+ = new AzureMLBatchExecutionActivity().withName("djkrosqxvffrn")
+ .withDescription("wvjgyjoklngjs")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("sqdnasj")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("glixhapvwacwrcte")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("axrsyxeqwgaeice")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("czaqgevsnnqvkuf").withValue("datazwgw"),
+ new UserProperty().withName("dv").withValue("dataskffqqaobbq")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tvryszqzvemwne")
+ .withParameters(mapOf("ywdgrskdlt", "datawjcgryolbqcft", "vmcxljlpyh", "datafzyijn")))
+ .withPolicy(new ActivityPolicy().withTimeout("datadjgcuew")
+ .withRetry("dataqbqgfq")
+ .withRetryIntervalInSeconds(1286883147)
+ .withSecureInput(true)
+ .withSecureOutput(true)
+ .withAdditionalProperties(mapOf()))
+ .withGlobalParameters(mapOf("hghorgji", "datajaktgtwvzp", "bqdsuaazkouvvgcw", "dataragqcwcdbtopuyi",
+ "gaofwo", "dataimhjbxwr", "xp", "dataz"))
+ .withWebServiceOutputs(
+ mapOf("euegrdit",
+ new AzureMLWebServiceFile().withFilePath("datax")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("m")
+ .withParameters(mapOf("uxjh", "datafsh", "uz", "datauzirhcghnclfahr"))),
+ "xabtlmszqaudaip",
+ new AzureMLWebServiceFile().withFilePath("dataptpq")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ajggmmiwoisql")
+ .withParameters(mapOf("cptoihoyvua", "datafycnpovnjzaaox", "gslqpz", "datafju",
+ "vfbzzscepo", "dataxwdanlgc", "yiuhjqdw", "datagzppufueiaiece")))))
+ .withWebServiceInputs(
+ mapOf("qgivyxoj",
+ new AzureMLWebServiceFile().withFilePath("dataxjkopivszejb")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("trmhabzjemqvl")
+ .withParameters(mapOf("cgqh", "datacaxnbqsjz"))),
+ "aubhrbtthzfgpzy",
+ new AzureMLWebServiceFile().withFilePath("datamussvurslwd")
+ .withLinkedServiceName(
+ new LinkedServiceReference().withReferenceName("n")
+ .withParameters(mapOf("daql", "dataalv", "whtws", "datasoqrhwla", "srvtrwswb",
+ "dataliwpzucetzi"))),
+ "dyxjicikzm",
+ new AzureMLWebServiceFile().withFilePath("dataivusehyvqxjbqfcl")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("jecajtuo")
+ .withParameters(mapOf("xn", "datalzxuakbavpk", "vsgx", "datarbckfzb", "htlvja",
+ "dataijnvsjgnbdhhqs"))),
+ "emsl",
+ new AzureMLWebServiceFile().withFilePath("datadddfjmirbnfc")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("l")
+ .withParameters(mapOf("q", "datavpfspfdfrymrf", "w", "dataxln", "qhzotkowi", "datagi",
+ "wymrmuioepi", "datauerhzyl")))));
model = BinaryData.fromObject(model).toObject(AzureMLBatchExecutionActivity.class);
- Assertions.assertEquals("qdostvx", model.name());
- Assertions.assertEquals("fnmnfndrbkko", model.description());
+ Assertions.assertEquals("djkrosqxvffrn", model.name());
+ Assertions.assertEquals("wvjgyjoklngjs", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("qfze", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("mvlkuvbesrawzxnw", model.userProperties().get(0).name());
- Assertions.assertEquals("vhwkwzxjezys", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1459080325, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("qamvdnexqvt",
- model.webServiceOutputs().get("chqigjamozlh").linkedServiceName().referenceName());
- Assertions.assertEquals("upjgebnsuiklnc",
- model.webServiceInputs().get("f").linkedServiceName().referenceName());
+ Assertions.assertEquals("sqdnasj", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("czaqgevsnnqvkuf", model.userProperties().get(0).name());
+ Assertions.assertEquals("tvryszqzvemwne", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1286883147, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("m", model.webServiceOutputs().get("euegrdit").linkedServiceName().referenceName());
+ Assertions.assertEquals("trmhabzjemqvl",
+ model.webServiceInputs().get("qgivyxoj").linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTypePropertiesTests.java
index 99d796ac9260..84d71337b488 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLBatchExecutionActivityTypePropertiesTests.java
@@ -16,49 +16,43 @@ public final class AzureMLBatchExecutionActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMLBatchExecutionActivityTypeProperties model = BinaryData.fromString(
- "{\"globalParameters\":{\"xoohyesmlscvhra\":\"databdqmjcedfpub\",\"dxhkdy\":\"dataybbor\"},\"webServiceOutputs\":{\"ekkxlibs\":{\"filePath\":\"dataufqzuduqfdeigx\",\"linkedServiceName\":{\"referenceName\":\"plpgftz\",\"parameters\":{\"b\":\"dataf\"}}},\"erzthcfnrle\":{\"filePath\":\"datacvceglvz\",\"linkedServiceName\":{\"referenceName\":\"ujvv\",\"parameters\":{\"vxnumvorosqessp\":\"datadpclazaoytkub\",\"rqspwsiitzbyu\":\"datautk\",\"ovpsflmwduis\":\"datalumqmo\",\"e\":\"datavlunyqe\"}}},\"ydllhim\":{\"filePath\":\"dataghhcf\",\"linkedServiceName\":{\"referenceName\":\"zmjmfl\",\"parameters\":{\"vauxkgklqu\":\"datalkmtrrcbu\",\"zvarqi\":\"dataxewcdprqjsmhk\"}}}},\"webServiceInputs\":{\"imbqdsuaa\":{\"filePath\":\"dataxhxz\",\"linkedServiceName\":{\"referenceName\":\"bxhmd\",\"parameters\":{\"so\":\"databuapr\",\"cy\":\"dataqicrtibad\",\"w\":\"dataxbjaktg\",\"wcdbtopu\":\"datazpshghorgjidragq\"}}},\"m\":{\"filePath\":\"datakou\",\"linkedServiceName\":{\"referenceName\":\"vgcwsimhjbx\",\"parameters\":{\"z\":\"datagaofwo\",\"bnx\":\"dataxp\"}}},\"oggzppufu\":{\"filePath\":\"datays\",\"linkedServiceName\":{\"referenceName\":\"shbuxjhqu\",\"parameters\":{\"teuegrd\":\"datahcghnclfahryu\",\"miwoisqlsxzfycnp\":\"datatcptpqoajgg\",\"xwcptoihoyv\":\"datavnjzaa\",\"anlgczvfbzzsce\":\"dataaxfjuzgslqpzdxw\"}}}}}")
+ "{\"globalParameters\":{\"vinvzdnubs\":\"dataaqfqgmwdo\",\"ilbiwacxldho\":\"dataskgiy\",\"cvtbgznpx\":\"datacdpwxh\",\"zo\":\"dataxcshtlqhikmfzdlh\"},\"webServiceOutputs\":{\"tnyvigjbxhjpsgpr\":{\"filePath\":\"datauziaztmxwmjaevw\",\"linkedServiceName\":{\"referenceName\":\"dn\",\"parameters\":{\"vdykxg\":\"datakunhwdirtiyraqy\",\"bycraryxrttn\":\"datafhvhynsyhzysuoq\",\"tstlgdvvpxhdefy\":\"datajhjbfoemm\",\"jyqhcowouoih\":\"dataitbjmva\"}}},\"ni\":{\"filePath\":\"datampzb\",\"linkedServiceName\":{\"referenceName\":\"iakyflryhvph\",\"parameters\":{\"bgstmlhrziggcaz\":\"dataiyidzbpfwlxxwpy\"}}},\"fggheqllrp\":{\"filePath\":\"datakkengowcut\",\"linkedServiceName\":{\"referenceName\":\"hmxmjm\",\"parameters\":{\"iimennxvqjakqd\":\"dataich\",\"zuuguze\":\"datannef\"}}}},\"webServiceInputs\":{\"pdovlp\":{\"filePath\":\"dataxqfkrvmvdqhageh\",\"linkedServiceName\":{\"referenceName\":\"hqeqtlsi\",\"parameters\":{\"gwidgx\":\"datagtupkmvxeub\"}}},\"fxkud\":{\"filePath\":\"datamcmfvyhmivyblt\",\"linkedServiceName\":{\"referenceName\":\"akmtvoprg\",\"parameters\":{\"orxibw\":\"datay\"}}}}}")
.toObject(AzureMLBatchExecutionActivityTypeProperties.class);
- Assertions.assertEquals("plpgftz",
- model.webServiceOutputs().get("ekkxlibs").linkedServiceName().referenceName());
- Assertions.assertEquals("bxhmd", model.webServiceInputs().get("imbqdsuaa").linkedServiceName().referenceName());
+ Assertions.assertEquals("dn",
+ model.webServiceOutputs().get("tnyvigjbxhjpsgpr").linkedServiceName().referenceName());
+ Assertions.assertEquals("hqeqtlsi", model.webServiceInputs().get("pdovlp").linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMLBatchExecutionActivityTypeProperties model
- = new AzureMLBatchExecutionActivityTypeProperties()
- .withGlobalParameters(mapOf("xoohyesmlscvhra", "databdqmjcedfpub", "dxhkdy", "dataybbor"))
- .withWebServiceOutputs(mapOf("ekkxlibs",
- new AzureMLWebServiceFile().withFilePath("dataufqzuduqfdeigx")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("plpgftz")
- .withParameters(mapOf("b", "dataf"))),
- "erzthcfnrle",
- new AzureMLWebServiceFile().withFilePath("datacvceglvz")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ujvv")
- .withParameters(mapOf("vxnumvorosqessp", "datadpclazaoytkub", "rqspwsiitzbyu", "datautk",
- "ovpsflmwduis", "datalumqmo", "e", "datavlunyqe"))),
- "ydllhim",
- new AzureMLWebServiceFile().withFilePath("dataghhcf")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zmjmfl")
- .withParameters(mapOf("vauxkgklqu", "datalkmtrrcbu", "zvarqi", "dataxewcdprqjsmhk")))))
- .withWebServiceInputs(mapOf("imbqdsuaa",
- new AzureMLWebServiceFile().withFilePath("dataxhxz")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bxhmd")
- .withParameters(mapOf("so", "databuapr", "cy", "dataqicrtibad", "w", "dataxbjaktg",
- "wcdbtopu", "datazpshghorgjidragq"))),
- "m",
- new AzureMLWebServiceFile().withFilePath("datakou")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vgcwsimhjbx")
- .withParameters(mapOf("z", "datagaofwo", "bnx", "dataxp"))),
- "oggzppufu",
- new AzureMLWebServiceFile().withFilePath("datays")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("shbuxjhqu")
- .withParameters(mapOf("teuegrd", "datahcghnclfahryu", "miwoisqlsxzfycnp", "datatcptpqoajgg",
- "xwcptoihoyv", "datavnjzaa", "anlgczvfbzzsce", "dataaxfjuzgslqpzdxw")))));
+ AzureMLBatchExecutionActivityTypeProperties model = new AzureMLBatchExecutionActivityTypeProperties()
+ .withGlobalParameters(mapOf("vinvzdnubs", "dataaqfqgmwdo", "ilbiwacxldho", "dataskgiy", "cvtbgznpx",
+ "datacdpwxh", "zo", "dataxcshtlqhikmfzdlh"))
+ .withWebServiceOutputs(mapOf("tnyvigjbxhjpsgpr",
+ new AzureMLWebServiceFile().withFilePath("datauziaztmxwmjaevw")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dn")
+ .withParameters(mapOf("vdykxg", "datakunhwdirtiyraqy", "bycraryxrttn", "datafhvhynsyhzysuoq",
+ "tstlgdvvpxhdefy", "datajhjbfoemm", "jyqhcowouoih", "dataitbjmva"))),
+ "ni",
+ new AzureMLWebServiceFile().withFilePath("datampzb")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("iakyflryhvph")
+ .withParameters(mapOf("bgstmlhrziggcaz", "dataiyidzbpfwlxxwpy"))),
+ "fggheqllrp",
+ new AzureMLWebServiceFile().withFilePath("datakkengowcut")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hmxmjm")
+ .withParameters(mapOf("iimennxvqjakqd", "dataich", "zuuguze", "datannef")))))
+ .withWebServiceInputs(mapOf("pdovlp",
+ new AzureMLWebServiceFile().withFilePath("dataxqfkrvmvdqhageh")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hqeqtlsi")
+ .withParameters(mapOf("gwidgx", "datagtupkmvxeub"))),
+ "fxkud",
+ new AzureMLWebServiceFile().withFilePath("datamcmfvyhmivyblt")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("akmtvoprg")
+ .withParameters(mapOf("orxibw", "datay")))));
model = BinaryData.fromObject(model).toObject(AzureMLBatchExecutionActivityTypeProperties.class);
- Assertions.assertEquals("plpgftz",
- model.webServiceOutputs().get("ekkxlibs").linkedServiceName().referenceName());
- Assertions.assertEquals("bxhmd", model.webServiceInputs().get("imbqdsuaa").linkedServiceName().referenceName());
+ Assertions.assertEquals("dn",
+ model.webServiceOutputs().get("tnyvigjbxhjpsgpr").linkedServiceName().referenceName());
+ Assertions.assertEquals("hqeqtlsi", model.webServiceInputs().get("pdovlp").linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTests.java
index 91454ed0b27e..99a84f6c3e4f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTests.java
@@ -22,63 +22,67 @@ public final class AzureMLExecutePipelineActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMLExecutePipelineActivity model = BinaryData.fromString(
- "{\"type\":\"AzureMLExecutePipeline\",\"typeProperties\":{\"mlPipelineId\":\"datat\",\"mlPipelineEndpointId\":\"dataawtfyzq\",\"version\":\"dataglixhapvwacwrcte\",\"experimentName\":\"dataucnknzncoxeop\",\"mlPipelineParameters\":\"dataleuaxrsyxeqwgaei\",\"dataPathAssignments\":\"dataovrcdcidcxkyw\",\"mlParentRunId\":\"dataztssqbclaeciwz\",\"continueOnStepFailure\":\"datattkhaxqyinfdmq\"},\"linkedServiceName\":{\"referenceName\":\"jkhqaxpicza\",\"parameters\":{\"ufezwgwmdv\":\"datavsnnqv\",\"dkjusqhr\":\"dataskffqqaobbq\",\"ykhtsycct\":\"dataadffdr\",\"siembc\":\"datarvn\"}},\"policy\":{\"timeout\":\"datam\",\"retry\":\"datawh\",\"retryIntervalInSeconds\":886184387,\"secureInput\":true,\"secureOutput\":true,\"\":{\"oa\":\"datacorqbmk\"}},\"name\":\"aaqfqgmwdohvinvz\",\"description\":\"ubsaskgi\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"acxldhoqcdpwx\",\"dependencyConditions\":[\"Skipped\",\"Skipped\"],\"\":{\"axc\":\"datagznp\",\"zo\":\"datahtlqhikmfzdlh\",\"idnj\":\"datahnuziaztmxwmjaev\"}}],\"userProperties\":[{\"name\":\"unhwdirtiyraqyav\",\"value\":\"datayk\"},{\"name\":\"gcfh\",\"value\":\"datah\"},{\"name\":\"ns\",\"value\":\"datahzysuoqfbyc\"},{\"name\":\"aryxrttn\",\"value\":\"datajhjbfoemm\"}],\"\":{\"jm\":\"datatlgdvvpxhdefydit\"}}")
+ "{\"type\":\"AzureMLExecutePipeline\",\"typeProperties\":{\"mlPipelineId\":\"datamymalvoydqgelc\",\"mlPipelineEndpointId\":\"dataccco\",\"version\":\"dataljzqvevmzpo\",\"experimentName\":\"datah\",\"mlPipelineParameters\":\"dataipnbdkhvxt\",\"dataPathAssignments\":\"dataihydwkdvy\",\"mlParentRunId\":\"datazqjpyq\",\"continueOnStepFailure\":\"dataqydtllpwzaya\"},\"linkedServiceName\":{\"referenceName\":\"ell\",\"parameters\":{\"edsnubirusknpy\":\"dataplhre\"}},\"policy\":{\"timeout\":\"datatoktrjwnqfdgcr\",\"retry\":\"datagktmzooszvungkkf\",\"retryIntervalInSeconds\":1773094085,\"secureInput\":false,\"secureOutput\":false,\"\":{\"pidb\":\"datatyeqeasiadscjha\",\"lcowb\":\"dataqvi\",\"w\":\"datapvmndqmzcgqedono\",\"eaahnkntldddk\":\"datawhvqkeuiy\"}},\"name\":\"pvusigw\",\"description\":\"qnxrrji\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ksoodqnouwxkeql\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Skipped\",\"Succeeded\"],\"\":{\"hxlcvzqhtgtadtoo\":\"datanqvudfi\"}},{\"activity\":\"k\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"petwgtmpytom\":\"datanlqwxskltz\",\"g\":\"datatubhvb\",\"zdazxfz\":\"datavpyjpaih\",\"sjnlekotqhd\":\"datallihwpsrdaoixgqt\"}}],\"userProperties\":[{\"name\":\"kn\",\"value\":\"datahyoimtfk\"},{\"name\":\"cdjswxeknhvcc\",\"value\":\"datauntghwcbgc\"},{\"name\":\"gbyfcbcak\",\"value\":\"dataqvhwzeukuml\"},{\"name\":\"f\",\"value\":\"databo\"}],\"\":{\"muiqir\":\"datawaiywzgv\",\"zbnqmxirspj\":\"datasznxz\",\"zisdnbourw\":\"dataakrbew\",\"sdluquyxgmzyqftl\":\"datag\"}}")
.toObject(AzureMLExecutePipelineActivity.class);
- Assertions.assertEquals("aaqfqgmwdohvinvz", model.name());
- Assertions.assertEquals("ubsaskgi", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("acxldhoqcdpwx", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("unhwdirtiyraqyav", model.userProperties().get(0).name());
- Assertions.assertEquals("jkhqaxpicza", model.linkedServiceName().referenceName());
- Assertions.assertEquals(886184387, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("pvusigw", model.name());
+ Assertions.assertEquals("qnxrrji", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("ksoodqnouwxkeql", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("kn", model.userProperties().get(0).name());
+ Assertions.assertEquals("ell", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1773094085, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(false, model.policy().secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMLExecutePipelineActivity model = new AzureMLExecutePipelineActivity().withName("aaqfqgmwdohvinvz")
- .withDescription("ubsaskgi")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("acxldhoqcdpwx")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("unhwdirtiyraqyav").withValue("datayk"),
- new UserProperty().withName("gcfh").withValue("datah"),
- new UserProperty().withName("ns").withValue("datahzysuoqfbyc"),
- new UserProperty().withName("aryxrttn").withValue("datajhjbfoemm")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("jkhqaxpicza")
- .withParameters(mapOf("ufezwgwmdv", "datavsnnqv", "dkjusqhr", "dataskffqqaobbq", "ykhtsycct",
- "dataadffdr", "siembc", "datarvn")))
- .withPolicy(new ActivityPolicy().withTimeout("datam")
- .withRetry("datawh")
- .withRetryIntervalInSeconds(886184387)
- .withSecureInput(true)
- .withSecureOutput(true)
+ AzureMLExecutePipelineActivity model = new AzureMLExecutePipelineActivity().withName("pvusigw")
+ .withDescription("qnxrrji")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("ksoodqnouwxkeql")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
+ DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("k")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("kn").withValue("datahyoimtfk"),
+ new UserProperty().withName("cdjswxeknhvcc").withValue("datauntghwcbgc"),
+ new UserProperty().withName("gbyfcbcak").withValue("dataqvhwzeukuml"),
+ new UserProperty().withName("f").withValue("databo")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ell")
+ .withParameters(mapOf("edsnubirusknpy", "dataplhre")))
+ .withPolicy(new ActivityPolicy().withTimeout("datatoktrjwnqfdgcr")
+ .withRetry("datagktmzooszvungkkf")
+ .withRetryIntervalInSeconds(1773094085)
+ .withSecureInput(false)
+ .withSecureOutput(false)
.withAdditionalProperties(mapOf()))
- .withMlPipelineId("datat")
- .withMlPipelineEndpointId("dataawtfyzq")
- .withVersion("dataglixhapvwacwrcte")
- .withExperimentName("dataucnknzncoxeop")
- .withMlPipelineParameters("dataleuaxrsyxeqwgaei")
- .withDataPathAssignments("dataovrcdcidcxkyw")
- .withMlParentRunId("dataztssqbclaeciwz")
- .withContinueOnStepFailure("datattkhaxqyinfdmq");
+ .withMlPipelineId("datamymalvoydqgelc")
+ .withMlPipelineEndpointId("dataccco")
+ .withVersion("dataljzqvevmzpo")
+ .withExperimentName("datah")
+ .withMlPipelineParameters("dataipnbdkhvxt")
+ .withDataPathAssignments("dataihydwkdvy")
+ .withMlParentRunId("datazqjpyq")
+ .withContinueOnStepFailure("dataqydtllpwzaya");
model = BinaryData.fromObject(model).toObject(AzureMLExecutePipelineActivity.class);
- Assertions.assertEquals("aaqfqgmwdohvinvz", model.name());
- Assertions.assertEquals("ubsaskgi", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("acxldhoqcdpwx", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("unhwdirtiyraqyav", model.userProperties().get(0).name());
- Assertions.assertEquals("jkhqaxpicza", model.linkedServiceName().referenceName());
- Assertions.assertEquals(886184387, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("pvusigw", model.name());
+ Assertions.assertEquals("qnxrrji", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("ksoodqnouwxkeql", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("kn", model.userProperties().get(0).name());
+ Assertions.assertEquals("ell", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1773094085, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(false, model.policy().secureOutput());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTypePropertiesTests.java
index 95bc88d9d247..7f9426d8fc7b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLExecutePipelineActivityTypePropertiesTests.java
@@ -11,21 +11,21 @@ public final class AzureMLExecutePipelineActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMLExecutePipelineActivityTypeProperties model = BinaryData.fromString(
- "{\"mlPipelineId\":\"datavjyqhcowou\",\"mlPipelineEndpointId\":\"datahltnyvig\",\"version\":\"dataxhjpsgprlmp\",\"experimentName\":\"dataaiakyflr\",\"mlPipelineParameters\":\"datav\",\"dataPathAssignments\":\"datakdciyidzb\",\"mlParentRunId\":\"datawlxxw\",\"continueOnStepFailure\":\"dataz\"}")
+ "{\"mlPipelineId\":\"dataecoufnxtynusqz\",\"mlPipelineEndpointId\":\"datanztwnylk\",\"version\":\"datawxcjfjuzwiw\",\"experimentName\":\"datauqzlmhpuqlsd\",\"mlPipelineParameters\":\"dataejxlzyyylyxuj\",\"dataPathAssignments\":\"dataccpv\",\"mlParentRunId\":\"datahobshogja\",\"continueOnStepFailure\":\"dataplfzj\"}")
.toObject(AzureMLExecutePipelineActivityTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureMLExecutePipelineActivityTypeProperties model
- = new AzureMLExecutePipelineActivityTypeProperties().withMlPipelineId("datavjyqhcowou")
- .withMlPipelineEndpointId("datahltnyvig")
- .withVersion("dataxhjpsgprlmp")
- .withExperimentName("dataaiakyflr")
- .withMlPipelineParameters("datav")
- .withDataPathAssignments("datakdciyidzb")
- .withMlParentRunId("datawlxxw")
- .withContinueOnStepFailure("dataz");
+ = new AzureMLExecutePipelineActivityTypeProperties().withMlPipelineId("dataecoufnxtynusqz")
+ .withMlPipelineEndpointId("datanztwnylk")
+ .withVersion("datawxcjfjuzwiw")
+ .withExperimentName("datauqzlmhpuqlsd")
+ .withMlPipelineParameters("dataejxlzyyylyxuj")
+ .withDataPathAssignments("dataccpv")
+ .withMlParentRunId("datahobshogja")
+ .withContinueOnStepFailure("dataplfzj");
model = BinaryData.fromObject(model).toObject(AzureMLExecutePipelineActivityTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTests.java
index 228187e90075..9abb76812070 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTests.java
@@ -22,71 +22,62 @@ public final class AzureMLUpdateResourceActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMLUpdateResourceActivity model = BinaryData.fromString(
- "{\"type\":\"AzureMLUpdateResource\",\"typeProperties\":{\"trainedModelName\":\"datajimussvur\",\"trainedModelLinkedServiceName\":{\"referenceName\":\"lwdxnx\",\"parameters\":{\"lksoqr\":\"datalvkda\"}},\"trainedModelFilePath\":\"datawlanwh\"},\"linkedServiceName\":{\"referenceName\":\"sxliwpzucetziss\",\"parameters\":{\"zfgpzyqiv\":\"datarwswbmaubhrbtt\",\"qxjbq\":\"datasehy\"}},\"policy\":{\"timeout\":\"datai\",\"retry\":\"datacajtuoyxdl\",\"retryIntervalInSeconds\":296107626,\"secureInput\":false,\"secureOutput\":false,\"\":{\"bckfzbqvsg\":\"datakrxnr\",\"sfhtlvjaxdyxjic\":\"dataeijnvsjgnbdhh\",\"mvdddfjmi\":\"datak\"}},\"name\":\"b\",\"description\":\"cqlsisvpfsp\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"fpqyxlncwag\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"ylpwymr\":\"dataotkowiruerh\",\"emsl\":\"datauioepi\"}},{\"activity\":\"z\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Skipped\"],\"\":{\"m\":\"datazv\",\"olbqcftrywd\":\"datanewmpwjcgr\"}},{\"activity\":\"rs\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"i\":\"dataz\",\"djgcuew\":\"datanxvmcxljlpyhdx\"}},{\"activity\":\"nq\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Skipped\"],\"\":{\"djmxvvtukyoubjn\":\"datamsxwe\"}}],\"userProperties\":[{\"name\":\"dinbfb\",\"value\":\"datawyvwv\"},{\"name\":\"gm\",\"value\":\"dataklqswwdbs\"}],\"\":{\"yjfquzxmtmsyiby\":\"dataysedqrbevobqrwng\"}}")
+ "{\"type\":\"AzureMLUpdateResource\",\"typeProperties\":{\"trainedModelName\":\"dataonlgnespkxnhfd\",\"trainedModelLinkedServiceName\":{\"referenceName\":\"zskvp\",\"parameters\":{\"bicj\":\"datandrhlbxr\",\"poczxmwbk\":\"dataaafvxxiizkehf\",\"inhqpq\":\"datawihbyufm\",\"huxzdgoto\":\"dataowxd\"}},\"trainedModelFilePath\":\"datan\"},\"linkedServiceName\":{\"referenceName\":\"uirjqxknaeuhxnp\",\"parameters\":{\"dvnaxtbnjmj\":\"datajaeqaolfyqjgob\",\"bdfmhzgtieybimit\":\"datagrwvl\",\"wab\":\"dataxeetkwloozeg\"}},\"policy\":{\"timeout\":\"datareftwhiivxytvje\",\"retry\":\"datakuzlfnbz\",\"retryIntervalInSeconds\":1739064620,\"secureInput\":true,\"secureOutput\":true,\"\":{\"xsdtnxggwxmqy\":\"datarvckyhncqyogvv\",\"npftaykovgxam\":\"datatl\",\"reufd\":\"datamqexyoylcwzk\"}},\"name\":\"vvelcrwhrpxsxy\",\"description\":\"lsmiaruvbo\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"obyyv\",\"dependencyConditions\":[\"Failed\",\"Failed\"],\"\":{\"vytluh\":\"datahg\",\"qikuj\":\"datahiycddo\",\"dbkezfkot\":\"datadoela\",\"hwjxn\":\"dataoszgc\"}}],\"userProperties\":[{\"name\":\"w\",\"value\":\"datavferl\"},{\"name\":\"hfzzqq\",\"value\":\"databj\"},{\"name\":\"shwxy\",\"value\":\"dataskjqejkm\"},{\"name\":\"twftlhsmtkxzio\",\"value\":\"datautcyjjbdgfrl\"}],\"\":{\"mirvmpi\":\"dataegqvusffzvpwzvh\"}}")
.toObject(AzureMLUpdateResourceActivity.class);
- Assertions.assertEquals("b", model.name());
- Assertions.assertEquals("cqlsisvpfsp", model.description());
+ Assertions.assertEquals("vvelcrwhrpxsxy", model.name());
+ Assertions.assertEquals("lsmiaruvbo", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("fpqyxlncwag", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("dinbfb", model.userProperties().get(0).name());
- Assertions.assertEquals("sxliwpzucetziss", model.linkedServiceName().referenceName());
- Assertions.assertEquals(296107626, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("lwdxnx", model.trainedModelLinkedServiceName().referenceName());
+ Assertions.assertEquals("obyyv", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("w", model.userProperties().get(0).name());
+ Assertions.assertEquals("uirjqxknaeuhxnp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1739064620, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("zskvp", model.trainedModelLinkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMLUpdateResourceActivity model = new AzureMLUpdateResourceActivity().withName("b")
- .withDescription("cqlsisvpfsp")
+ AzureMLUpdateResourceActivity model = new AzureMLUpdateResourceActivity().withName("vvelcrwhrpxsxy")
+ .withDescription("lsmiaruvbo")
.withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("fpqyxlncwag")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("z")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("rs")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("nq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED,
- DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("dinbfb").withValue("datawyvwv"),
- new UserProperty().withName("gm").withValue("dataklqswwdbs")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("sxliwpzucetziss")
- .withParameters(mapOf("zfgpzyqiv", "datarwswbmaubhrbtt", "qxjbq", "datasehy")))
- .withPolicy(new ActivityPolicy().withTimeout("datai")
- .withRetry("datacajtuoyxdl")
- .withRetryIntervalInSeconds(296107626)
- .withSecureInput(false)
- .withSecureOutput(false)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("obyyv")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("w").withValue("datavferl"),
+ new UserProperty().withName("hfzzqq").withValue("databj"),
+ new UserProperty().withName("shwxy").withValue("dataskjqejkm"),
+ new UserProperty().withName("twftlhsmtkxzio").withValue("datautcyjjbdgfrl")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("uirjqxknaeuhxnp")
+ .withParameters(mapOf("dvnaxtbnjmj", "datajaeqaolfyqjgob", "bdfmhzgtieybimit", "datagrwvl", "wab",
+ "dataxeetkwloozeg")))
+ .withPolicy(new ActivityPolicy().withTimeout("datareftwhiivxytvje")
+ .withRetry("datakuzlfnbz")
+ .withRetryIntervalInSeconds(1739064620)
+ .withSecureInput(true)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withTrainedModelName("datajimussvur")
- .withTrainedModelLinkedServiceName(
- new LinkedServiceReference().withReferenceName("lwdxnx").withParameters(mapOf("lksoqr", "datalvkda")))
- .withTrainedModelFilePath("datawlanwh");
+ .withTrainedModelName("dataonlgnespkxnhfd")
+ .withTrainedModelLinkedServiceName(new LinkedServiceReference().withReferenceName("zskvp")
+ .withParameters(mapOf("bicj", "datandrhlbxr", "poczxmwbk", "dataaafvxxiizkehf", "inhqpq",
+ "datawihbyufm", "huxzdgoto", "dataowxd")))
+ .withTrainedModelFilePath("datan");
model = BinaryData.fromObject(model).toObject(AzureMLUpdateResourceActivity.class);
- Assertions.assertEquals("b", model.name());
- Assertions.assertEquals("cqlsisvpfsp", model.description());
+ Assertions.assertEquals("vvelcrwhrpxsxy", model.name());
+ Assertions.assertEquals("lsmiaruvbo", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("fpqyxlncwag", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("dinbfb", model.userProperties().get(0).name());
- Assertions.assertEquals("sxliwpzucetziss", model.linkedServiceName().referenceName());
- Assertions.assertEquals(296107626, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("lwdxnx", model.trainedModelLinkedServiceName().referenceName());
+ Assertions.assertEquals("obyyv", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("w", model.userProperties().get(0).name());
+ Assertions.assertEquals("uirjqxknaeuhxnp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1739064620, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("zskvp", model.trainedModelLinkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTypePropertiesTests.java
index 473cb8617d4f..83a5725337ff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLUpdateResourceActivityTypePropertiesTests.java
@@ -15,21 +15,20 @@ public final class AzureMLUpdateResourceActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMLUpdateResourceActivityTypeProperties model = BinaryData.fromString(
- "{\"trainedModelName\":\"dataoupksas\",\"trainedModelLinkedServiceName\":{\"referenceName\":\"jkrosqxvffrnc\",\"parameters\":{\"i\":\"datajgyjoklngjsglz\",\"gakkszz\":\"datawsqdnasjup\",\"likeuqvq\":\"datadtvrgyebvq\"}},\"trainedModelFilePath\":\"dataotvfcbgffdlff\"}")
+ "{\"trainedModelName\":\"dataooo\",\"trainedModelLinkedServiceName\":{\"referenceName\":\"rnssthninzatd\",\"parameters\":{\"clqgteoepdpx\":\"datayltrxwabwd\",\"qq\":\"datazpqwfpqixomo\"}},\"trainedModelFilePath\":\"dataik\"}")
.toObject(AzureMLUpdateResourceActivityTypeProperties.class);
- Assertions.assertEquals("jkrosqxvffrnc", model.trainedModelLinkedServiceName().referenceName());
+ Assertions.assertEquals("rnssthninzatd", model.trainedModelLinkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMLUpdateResourceActivityTypeProperties model = new AzureMLUpdateResourceActivityTypeProperties()
- .withTrainedModelName("dataoupksas")
- .withTrainedModelLinkedServiceName(new LinkedServiceReference().withReferenceName("jkrosqxvffrnc")
- .withParameters(
- mapOf("i", "datajgyjoklngjsglz", "gakkszz", "datawsqdnasjup", "likeuqvq", "datadtvrgyebvq")))
- .withTrainedModelFilePath("dataotvfcbgffdlff");
+ AzureMLUpdateResourceActivityTypeProperties model
+ = new AzureMLUpdateResourceActivityTypeProperties().withTrainedModelName("dataooo")
+ .withTrainedModelLinkedServiceName(new LinkedServiceReference().withReferenceName("rnssthninzatd")
+ .withParameters(mapOf("clqgteoepdpx", "datayltrxwabwd", "qq", "datazpqwfpqixomo")))
+ .withTrainedModelFilePath("dataik");
model = BinaryData.fromObject(model).toObject(AzureMLUpdateResourceActivityTypeProperties.class);
- Assertions.assertEquals("jkrosqxvffrnc", model.trainedModelLinkedServiceName().referenceName());
+ Assertions.assertEquals("rnssthninzatd", model.trainedModelLinkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLWebServiceFileTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLWebServiceFileTests.java
index aff2cddf6e77..645a109813f0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLWebServiceFileTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMLWebServiceFileTests.java
@@ -15,19 +15,18 @@ public final class AzureMLWebServiceFileTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMLWebServiceFile model = BinaryData.fromString(
- "{\"filePath\":\"dataiaiec\",\"linkedServiceName\":{\"referenceName\":\"xyiuhjqdw\",\"parameters\":{\"qnxjkopivszejbpt\":\"databtlmszqaudaip\",\"x\":\"datamhabzjemqvlouuc\",\"ncgqhpqgivyx\":\"databqsj\"}}}")
+ "{\"filePath\":\"datacwfo\",\"linkedServiceName\":{\"referenceName\":\"enmuevq\",\"parameters\":{\"lbpwegzd\":\"dataclg\"}}}")
.toObject(AzureMLWebServiceFile.class);
- Assertions.assertEquals("xyiuhjqdw", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("enmuevq", model.linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMLWebServiceFile model = new AzureMLWebServiceFile().withFilePath("dataiaiec")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xyiuhjqdw")
- .withParameters(mapOf("qnxjkopivszejbpt", "databtlmszqaudaip", "x", "datamhabzjemqvlouuc",
- "ncgqhpqgivyx", "databqsj")));
+ AzureMLWebServiceFile model = new AzureMLWebServiceFile().withFilePath("datacwfo")
+ .withLinkedServiceName(
+ new LinkedServiceReference().withReferenceName("enmuevq").withParameters(mapOf("lbpwegzd", "dataclg")));
model = BinaryData.fromObject(model).toObject(AzureMLWebServiceFile.class);
- Assertions.assertEquals("xyiuhjqdw", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("enmuevq", model.linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBSourceTests.java
index f2fb1373abe3..b9ecc9370786 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBSourceTests.java
@@ -11,19 +11,19 @@ public final class AzureMariaDBSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMariaDBSource model = BinaryData.fromString(
- "{\"type\":\"AzureMariaDBSource\",\"query\":\"datamezfyelf\",\"queryTimeout\":\"databkbhjdkqfj\",\"additionalColumns\":\"datayzj\",\"sourceRetryCount\":\"dataa\",\"sourceRetryWait\":\"datagatynkihb\",\"maxConcurrentConnections\":\"dataxybtowjz\",\"disableMetricsCollection\":\"datapzaenlzjxztg\",\"\":{\"tczzv\":\"dataunvwvaolfg\"}}")
+ "{\"type\":\"AzureMariaDBSource\",\"query\":\"dataqngpvvnbu\",\"queryTimeout\":\"datavkutl\",\"additionalColumns\":\"dataxuuqb\",\"sourceRetryCount\":\"datapbeswgkreozpufk\",\"sourceRetryWait\":\"datamzcbzgi\",\"maxConcurrentConnections\":\"dataqpegcgdndpb\",\"disableMetricsCollection\":\"dataeymmcbiktetzvqt\",\"\":{\"pdnbzqweohmlkzhx\":\"datavcsbyimygswdu\",\"haerhxd\":\"datadmauanxzrqt\",\"bqmoguy\":\"datahkbrkhjjbwelicrx\",\"dxljjzdbzk\":\"datamselwszqveak\"}}")
.toObject(AzureMariaDBSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMariaDBSource model = new AzureMariaDBSource().withSourceRetryCount("dataa")
- .withSourceRetryWait("datagatynkihb")
- .withMaxConcurrentConnections("dataxybtowjz")
- .withDisableMetricsCollection("datapzaenlzjxztg")
- .withQueryTimeout("databkbhjdkqfj")
- .withAdditionalColumns("datayzj")
- .withQuery("datamezfyelf");
+ AzureMariaDBSource model = new AzureMariaDBSource().withSourceRetryCount("datapbeswgkreozpufk")
+ .withSourceRetryWait("datamzcbzgi")
+ .withMaxConcurrentConnections("dataqpegcgdndpb")
+ .withDisableMetricsCollection("dataeymmcbiktetzvqt")
+ .withQueryTimeout("datavkutl")
+ .withAdditionalColumns("dataxuuqb")
+ .withQuery("dataqngpvvnbu");
model = BinaryData.fromObject(model).toObject(AzureMariaDBSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBTableDatasetTests.java
index ac3e80aac604..13474804f70e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMariaDBTableDatasetTests.java
@@ -19,34 +19,34 @@ public final class AzureMariaDBTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMariaDBTableDataset model = BinaryData.fromString(
- "{\"type\":\"AzureMariaDBTable\",\"typeProperties\":{\"tableName\":\"datahvxjuai\"},\"description\":\"znirnygtix\",\"structure\":\"datayob\",\"schema\":\"dataphvd\",\"linkedServiceName\":{\"referenceName\":\"orxzpqdi\",\"parameters\":{\"tkehldopjsxvbb\":\"datacltfcieileem\"}},\"parameters\":{\"bn\":{\"type\":\"Array\",\"defaultValue\":\"datakm\"},\"zwmzhcmrloq\":{\"type\":\"Bool\",\"defaultValue\":\"dataidipwt\"},\"dnmbjqbngzldv\":{\"type\":\"Bool\",\"defaultValue\":\"datatyzavkyjjl\"}},\"annotations\":[\"dataoptythctoxo\"],\"folder\":{\"name\":\"qnerw\"},\"\":{\"pejomeqgxhwisp\":\"datavidsssfzsgzgu\",\"xirppbiichlygkv\":\"dataogdblwjsbaqxaxt\",\"wonkrnizdxywabki\":\"datai\",\"aptgvnaqyjukka\":\"datani\"}}")
+ "{\"type\":\"AzureMariaDBTable\",\"typeProperties\":{\"tableName\":\"datatythct\"},\"description\":\"oip\",\"structure\":\"datanerwhem\",\"schema\":\"datadsssfzsgzguspej\",\"linkedServiceName\":{\"referenceName\":\"meqgxhwispsogdbl\",\"parameters\":{\"ichlygkvuixwonkr\":\"databaqxaxtuxirppb\",\"dxywabk\":\"datai\",\"aqyjukkajnne\":\"datatnipaptgv\"}},\"parameters\":{\"femiwfhhawbabhz\":{\"type\":\"SecureString\",\"defaultValue\":\"dataop\"},\"qnxyd\":{\"type\":\"String\",\"defaultValue\":\"datadi\"},\"uspaywvs\":{\"type\":\"Object\",\"defaultValue\":\"dataoiqz\"}},\"annotations\":[\"dataronzeafkxfmuwdb\",\"dataytqavouymkdeu\",\"dataxlvzpfdka\"],\"folder\":{\"name\":\"iw\"},\"\":{\"gjmpd\":\"datapqlktthbmrrmtr\",\"juzmu\":\"datarjzwawpewajccs\"}}")
.toObject(AzureMariaDBTableDataset.class);
- Assertions.assertEquals("znirnygtix", model.description());
- Assertions.assertEquals("orxzpqdi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("bn").type());
- Assertions.assertEquals("qnerw", model.folder().name());
+ Assertions.assertEquals("oip", model.description());
+ Assertions.assertEquals("meqgxhwispsogdbl", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("femiwfhhawbabhz").type());
+ Assertions.assertEquals("iw", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMariaDBTableDataset model = new AzureMariaDBTableDataset().withDescription("znirnygtix")
- .withStructure("datayob")
- .withSchema("dataphvd")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("orxzpqdi")
- .withParameters(mapOf("tkehldopjsxvbb", "datacltfcieileem")))
- .withParameters(mapOf("bn",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datakm"), "zwmzhcmrloq",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataidipwt"),
- "dnmbjqbngzldv",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datatyzavkyjjl")))
- .withAnnotations(Arrays.asList("dataoptythctoxo"))
- .withFolder(new DatasetFolder().withName("qnerw"))
- .withTableName("datahvxjuai");
+ AzureMariaDBTableDataset model = new AzureMariaDBTableDataset().withDescription("oip")
+ .withStructure("datanerwhem")
+ .withSchema("datadsssfzsgzguspej")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("meqgxhwispsogdbl")
+ .withParameters(mapOf("ichlygkvuixwonkr", "databaqxaxtuxirppb", "dxywabk", "datai", "aqyjukkajnne",
+ "datatnipaptgv")))
+ .withParameters(mapOf("femiwfhhawbabhz",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataop"), "qnxyd",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datadi"), "uspaywvs",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataoiqz")))
+ .withAnnotations(Arrays.asList("dataronzeafkxfmuwdb", "dataytqavouymkdeu", "dataxlvzpfdka"))
+ .withFolder(new DatasetFolder().withName("iw"))
+ .withTableName("datatythct");
model = BinaryData.fromObject(model).toObject(AzureMariaDBTableDataset.class);
- Assertions.assertEquals("znirnygtix", model.description());
- Assertions.assertEquals("orxzpqdi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("bn").type());
- Assertions.assertEquals("qnerw", model.folder().name());
+ Assertions.assertEquals("oip", model.description());
+ Assertions.assertEquals("meqgxhwispsogdbl", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("femiwfhhawbabhz").type());
+ Assertions.assertEquals("iw", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSinkTests.java
index 93e8ddf50a97..795b652b20fa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSinkTests.java
@@ -11,19 +11,19 @@ public final class AzureMySqlSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMySqlSink model = BinaryData.fromString(
- "{\"type\":\"AzureMySqlSink\",\"preCopyScript\":\"datamhookefdgfexakct\",\"writeBatchSize\":\"datapszdn\",\"writeBatchTimeout\":\"datao\",\"sinkRetryCount\":\"dataqxmdievkmrso\",\"sinkRetryWait\":\"datayiheheimuqqmd\",\"maxConcurrentConnections\":\"datawxfmrm\",\"disableMetricsCollection\":\"dataf\",\"\":{\"xdldhhkdeviwp\":\"dataypmthfvszlaf\",\"nu\":\"datahfxvl\"}}")
+ "{\"type\":\"AzureMySqlSink\",\"preCopyScript\":\"datavijdr\",\"writeBatchSize\":\"datayqvhz\",\"writeBatchTimeout\":\"datayvhrenozl\",\"sinkRetryCount\":\"dataqfghlosho\",\"sinkRetryWait\":\"datakpcmtsbandesalv\",\"maxConcurrentConnections\":\"datawrljmlo\",\"disableMetricsCollection\":\"datatzvtfyqe\",\"\":{\"xhcygfg\":\"databsyni\",\"aosttbwap\":\"datamdbazggr\"}}")
.toObject(AzureMySqlSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMySqlSink model = new AzureMySqlSink().withWriteBatchSize("datapszdn")
- .withWriteBatchTimeout("datao")
- .withSinkRetryCount("dataqxmdievkmrso")
- .withSinkRetryWait("datayiheheimuqqmd")
- .withMaxConcurrentConnections("datawxfmrm")
- .withDisableMetricsCollection("dataf")
- .withPreCopyScript("datamhookefdgfexakct");
+ AzureMySqlSink model = new AzureMySqlSink().withWriteBatchSize("datayqvhz")
+ .withWriteBatchTimeout("datayvhrenozl")
+ .withSinkRetryCount("dataqfghlosho")
+ .withSinkRetryWait("datakpcmtsbandesalv")
+ .withMaxConcurrentConnections("datawrljmlo")
+ .withDisableMetricsCollection("datatzvtfyqe")
+ .withPreCopyScript("datavijdr");
model = BinaryData.fromObject(model).toObject(AzureMySqlSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSourceTests.java
index b6ffc17cb293..e29a131aca1a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlSourceTests.java
@@ -11,19 +11,19 @@ public final class AzureMySqlSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMySqlSource model = BinaryData.fromString(
- "{\"type\":\"AzureMySqlSource\",\"query\":\"datacyrdtrd\",\"queryTimeout\":\"datadmsktuvjh\",\"additionalColumns\":\"datatvyt\",\"sourceRetryCount\":\"datafbsgrzw\",\"sourceRetryWait\":\"datadudxqebtrpsplwt\",\"maxConcurrentConnections\":\"datacseybvtgcoznnjqx\",\"disableMetricsCollection\":\"datarnkuuotlymyb\",\"\":{\"j\":\"datarkxkmtuynugpt\",\"tqqshb\":\"dataisvfh\"}}")
+ "{\"type\":\"AzureMySqlSource\",\"query\":\"datagliufdctgsd\",\"queryTimeout\":\"dataxkddxoatlprs\",\"additionalColumns\":\"dataen\",\"sourceRetryCount\":\"datayyvvlgsa\",\"sourceRetryWait\":\"datavmnjtf\",\"maxConcurrentConnections\":\"datagx\",\"disableMetricsCollection\":\"datarctbxpuis\",\"\":{\"s\":\"datamgnpe\",\"ljabdmwalipb\":\"datasiyyco\",\"aknhmi\":\"dataqkdieuopw\"}}")
.toObject(AzureMySqlSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMySqlSource model = new AzureMySqlSource().withSourceRetryCount("datafbsgrzw")
- .withSourceRetryWait("datadudxqebtrpsplwt")
- .withMaxConcurrentConnections("datacseybvtgcoznnjqx")
- .withDisableMetricsCollection("datarnkuuotlymyb")
- .withQueryTimeout("datadmsktuvjh")
- .withAdditionalColumns("datatvyt")
- .withQuery("datacyrdtrd");
+ AzureMySqlSource model = new AzureMySqlSource().withSourceRetryCount("datayyvvlgsa")
+ .withSourceRetryWait("datavmnjtf")
+ .withMaxConcurrentConnections("datagx")
+ .withDisableMetricsCollection("datarctbxpuis")
+ .withQueryTimeout("dataxkddxoatlprs")
+ .withAdditionalColumns("dataen")
+ .withQuery("datagliufdctgsd");
model = BinaryData.fromObject(model).toObject(AzureMySqlSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTests.java
index c4a23400b31e..84a1fc8078b8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTests.java
@@ -19,34 +19,37 @@ public final class AzureMySqlTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMySqlTableDataset model = BinaryData.fromString(
- "{\"type\":\"AzureMySqlTable\",\"typeProperties\":{\"tableName\":\"dataalezaydpuzudege\",\"table\":\"datalieggotosmhssfnw\"},\"description\":\"kahhec\",\"structure\":\"datafmkcu\",\"schema\":\"datahdgwuzrono\",\"linkedServiceName\":{\"referenceName\":\"vhzfkdnwy\",\"parameters\":{\"zfzdjekeb\":\"datacikgxkk\",\"xz\":\"dataw\"}},\"parameters\":{\"lpj\":{\"type\":\"Bool\",\"defaultValue\":\"dataixirgcjfaiw\"},\"tzngxbsalewgu\":{\"type\":\"Array\",\"defaultValue\":\"datarxifqnfforxs\"}},\"annotations\":[\"datam\",\"datai\"],\"folder\":{\"name\":\"skcitlynkwfsaan\"},\"\":{\"vm\":\"databm\"}}")
+ "{\"type\":\"AzureMySqlTable\",\"typeProperties\":{\"tableName\":\"datapqokhdyncra\",\"table\":\"datasewbempfapmqnm\"},\"description\":\"yksygih\",\"structure\":\"datalmslnunkqvzlbbb\",\"schema\":\"datadexquaw\",\"linkedServiceName\":{\"referenceName\":\"xizbfzet\",\"parameters\":{\"pnbmajvvyxt\":\"dataw\",\"nakzixbkaybfmln\":\"datav\",\"nrzblxna\":\"datafwhrmvlaknujmw\"}},\"parameters\":{\"hl\":{\"type\":\"Int\",\"defaultValue\":\"datandcbs\"},\"dvt\":{\"type\":\"SecureString\",\"defaultValue\":\"datajkkovohwvprj\"},\"ffhvqii\":{\"type\":\"Array\",\"defaultValue\":\"datamdtacntjn\"},\"sxjbjkewrigl\":{\"type\":\"String\",\"defaultValue\":\"datatwskkfkuyikmxhh\"}},\"annotations\":[\"datarefeclflxcjf\",\"datazwncvdefxonz\",\"datapcjptnnt\"],\"folder\":{\"name\":\"jqpzj\"},\"\":{\"h\":\"datajr\",\"agwviqehmdqvaoli\":\"datagsjbi\",\"m\":\"dataxdfsfvkjc\",\"rkd\":\"datarsvxphtjnhptj\"}}")
.toObject(AzureMySqlTableDataset.class);
- Assertions.assertEquals("kahhec", model.description());
- Assertions.assertEquals("vhzfkdnwy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("lpj").type());
- Assertions.assertEquals("skcitlynkwfsaan", model.folder().name());
+ Assertions.assertEquals("yksygih", model.description());
+ Assertions.assertEquals("xizbfzet", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("hl").type());
+ Assertions.assertEquals("jqpzj", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureMySqlTableDataset model = new AzureMySqlTableDataset().withDescription("kahhec")
- .withStructure("datafmkcu")
- .withSchema("datahdgwuzrono")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vhzfkdnwy")
- .withParameters(mapOf("zfzdjekeb", "datacikgxkk", "xz", "dataw")))
- .withParameters(mapOf("lpj",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataixirgcjfaiw"),
- "tzngxbsalewgu",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datarxifqnfforxs")))
- .withAnnotations(Arrays.asList("datam", "datai"))
- .withFolder(new DatasetFolder().withName("skcitlynkwfsaan"))
- .withTableName("dataalezaydpuzudege")
- .withTable("datalieggotosmhssfnw");
+ AzureMySqlTableDataset model = new AzureMySqlTableDataset().withDescription("yksygih")
+ .withStructure("datalmslnunkqvzlbbb")
+ .withSchema("datadexquaw")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xizbfzet")
+ .withParameters(
+ mapOf("pnbmajvvyxt", "dataw", "nakzixbkaybfmln", "datav", "nrzblxna", "datafwhrmvlaknujmw")))
+ .withParameters(mapOf("hl",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datandcbs"), "dvt",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datajkkovohwvprj"),
+ "ffhvqii", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datamdtacntjn"),
+ "sxjbjkewrigl",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datatwskkfkuyikmxhh")))
+ .withAnnotations(Arrays.asList("datarefeclflxcjf", "datazwncvdefxonz", "datapcjptnnt"))
+ .withFolder(new DatasetFolder().withName("jqpzj"))
+ .withTableName("datapqokhdyncra")
+ .withTable("datasewbempfapmqnm");
model = BinaryData.fromObject(model).toObject(AzureMySqlTableDataset.class);
- Assertions.assertEquals("kahhec", model.description());
- Assertions.assertEquals("vhzfkdnwy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("lpj").type());
- Assertions.assertEquals("skcitlynkwfsaan", model.folder().name());
+ Assertions.assertEquals("yksygih", model.description());
+ Assertions.assertEquals("xizbfzet", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("hl").type());
+ Assertions.assertEquals("jqpzj", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTypePropertiesTests.java
index af6d9579de3c..5f70c0f52981 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureMySqlTableDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class AzureMySqlTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureMySqlTableDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datad\",\"table\":\"dataiuajklnacgdn\"}")
+ = BinaryData.fromString("{\"tableName\":\"dataz\",\"table\":\"datammydtdtftmizuz\"}")
.toObject(AzureMySqlTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureMySqlTableDatasetTypeProperties model
- = new AzureMySqlTableDatasetTypeProperties().withTableName("datad").withTable("dataiuajklnacgdn");
+ = new AzureMySqlTableDatasetTypeProperties().withTableName("dataz").withTable("datammydtdtftmizuz");
model = BinaryData.fromObject(model).toObject(AzureMySqlTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSinkTests.java
index ed368de6e4a4..6aed589dce5f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSinkTests.java
@@ -11,19 +11,19 @@ public final class AzurePostgreSqlSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzurePostgreSqlSink model = BinaryData.fromString(
- "{\"type\":\"AzurePostgreSqlSink\",\"preCopyScript\":\"datahbfttptsdee\",\"writeBatchSize\":\"dataovanag\",\"writeBatchTimeout\":\"dataacsfbmb\",\"sinkRetryCount\":\"dataefqku\",\"sinkRetryWait\":\"datayumoamqxwluslxyt\",\"maxConcurrentConnections\":\"databjledjxblobknfpd\",\"disableMetricsCollection\":\"datahzgj\",\"\":{\"ccypxsrhbqlbnufl\":\"datamctbg\",\"xhbpyoqfbj\":\"datazawkkz\",\"jpjnhwwyhx\":\"dataclboi\",\"hhw\":\"dataythxzrvjfsmfk\"}}")
+ "{\"type\":\"AzurePostgreSqlSink\",\"preCopyScript\":\"dataxtkmknacnfzcy\",\"writeBatchSize\":\"datahdjpagwszm\",\"writeBatchTimeout\":\"datagzfeyexbg\",\"sinkRetryCount\":\"datayo\",\"sinkRetryWait\":\"datawigvqgc\",\"maxConcurrentConnections\":\"datacqjg\",\"disableMetricsCollection\":\"dataxpbpj\",\"\":{\"ohehhtl\":\"datanvdabaodiytxq\"}}")
.toObject(AzurePostgreSqlSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzurePostgreSqlSink model = new AzurePostgreSqlSink().withWriteBatchSize("dataovanag")
- .withWriteBatchTimeout("dataacsfbmb")
- .withSinkRetryCount("dataefqku")
- .withSinkRetryWait("datayumoamqxwluslxyt")
- .withMaxConcurrentConnections("databjledjxblobknfpd")
- .withDisableMetricsCollection("datahzgj")
- .withPreCopyScript("datahbfttptsdee");
+ AzurePostgreSqlSink model = new AzurePostgreSqlSink().withWriteBatchSize("datahdjpagwszm")
+ .withWriteBatchTimeout("datagzfeyexbg")
+ .withSinkRetryCount("datayo")
+ .withSinkRetryWait("datawigvqgc")
+ .withMaxConcurrentConnections("datacqjg")
+ .withDisableMetricsCollection("dataxpbpj")
+ .withPreCopyScript("dataxtkmknacnfzcy");
model = BinaryData.fromObject(model).toObject(AzurePostgreSqlSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSourceTests.java
index 20ce14581055..208308b32c66 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlSourceTests.java
@@ -11,19 +11,19 @@ public final class AzurePostgreSqlSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzurePostgreSqlSource model = BinaryData.fromString(
- "{\"type\":\"AzurePostgreSqlSource\",\"query\":\"datapsoeocvywtyehln\",\"queryTimeout\":\"dataqeply\",\"additionalColumns\":\"dataad\",\"sourceRetryCount\":\"datagwdxoxjlvvvz\",\"sourceRetryWait\":\"datajvyintgkve\",\"maxConcurrentConnections\":\"dataeldnmb\",\"disableMetricsCollection\":\"databii\",\"\":{\"jaagfeiw\":\"datakxi\",\"zmsivqegmpfzbrh\":\"datauxqw\",\"tkrsjspziiev\":\"dataqj\",\"auyxyoyjas\":\"datattsz\"}}")
+ "{\"type\":\"AzurePostgreSqlSource\",\"query\":\"dataxllfwxdou\",\"queryTimeout\":\"datazpaqjahjxgedtmzh\",\"additionalColumns\":\"datahktywtac\",\"sourceRetryCount\":\"datakie\",\"sourceRetryWait\":\"dataqrfassiiil\",\"maxConcurrentConnections\":\"datargahscay\",\"disableMetricsCollection\":\"datagc\",\"\":{\"vqopxun\":\"dataieqonsbukznxd\"}}")
.toObject(AzurePostgreSqlSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzurePostgreSqlSource model = new AzurePostgreSqlSource().withSourceRetryCount("datagwdxoxjlvvvz")
- .withSourceRetryWait("datajvyintgkve")
- .withMaxConcurrentConnections("dataeldnmb")
- .withDisableMetricsCollection("databii")
- .withQueryTimeout("dataqeply")
- .withAdditionalColumns("dataad")
- .withQuery("datapsoeocvywtyehln");
+ AzurePostgreSqlSource model = new AzurePostgreSqlSource().withSourceRetryCount("datakie")
+ .withSourceRetryWait("dataqrfassiiil")
+ .withMaxConcurrentConnections("datargahscay")
+ .withDisableMetricsCollection("datagc")
+ .withQueryTimeout("datazpaqjahjxgedtmzh")
+ .withAdditionalColumns("datahktywtac")
+ .withQuery("dataxllfwxdou");
model = BinaryData.fromObject(model).toObject(AzurePostgreSqlSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTests.java
index ae1433709d7e..0c35a5fb2169 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTests.java
@@ -19,40 +19,37 @@ public final class AzurePostgreSqlTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzurePostgreSqlTableDataset model = BinaryData.fromString(
- "{\"type\":\"AzurePostgreSqlTable\",\"typeProperties\":{\"tableName\":\"datarllld\",\"table\":\"datanbdzwils\",\"schema\":\"datayiqjz\"},\"description\":\"rd\",\"structure\":\"datantpfxxgjahyxfw\",\"schema\":\"datat\",\"linkedServiceName\":{\"referenceName\":\"veyfbkqynlzxeme\",\"parameters\":{\"ehdmvfoyrxxxff\":\"datajck\",\"cgcsapvbcqpf\":\"datamcuanszeerv\",\"vpyr\":\"datasekijhminenkb\",\"fvvcwvurkmjufa\":\"datavorlfqmljewyn\"}},\"parameters\":{\"vrkkfcwxizkstxne\":{\"type\":\"SecureString\",\"defaultValue\":\"databsotmynklnmrznm\"},\"tc\":{\"type\":\"Object\",\"defaultValue\":\"dataipx\"},\"tvsayyaeiiv\":{\"type\":\"Array\",\"defaultValue\":\"dataiuvnfaz\"},\"xqetxtdqius\":{\"type\":\"Float\",\"defaultValue\":\"dataqtjwrvewojoq\"}},\"annotations\":[\"datazljvgjijzqjhljsa\",\"datamjsisfqqhc\",\"dataecagsbfeiirpn\"],\"folder\":{\"name\":\"llfkchhgs\"},\"\":{\"cabaam\":\"datazcajlwmqc\",\"dyoqywsuarpzhry\":\"datakhdhpmkxdujkxpuq\"}}")
+ "{\"type\":\"AzurePostgreSqlTable\",\"typeProperties\":{\"tableName\":\"datascec\",\"table\":\"dataaajdfwrdkql\",\"schema\":\"datakfekdesbpjq\"},\"description\":\"lbh\",\"structure\":\"datapduibsr\",\"schema\":\"dataqnneqrypyurvs\",\"linkedServiceName\":{\"referenceName\":\"hovtuercp\",\"parameters\":{\"yb\":\"datawc\",\"nwczsraz\":\"datadzycxhaoegjzgplj\"}},\"parameters\":{\"uapasizzfmugykw\":{\"type\":\"SecureString\",\"defaultValue\":\"datacqhxhj\"},\"enndzgthdzit\":{\"type\":\"Int\",\"defaultValue\":\"datauo\"},\"wonadezmzxvfybxm\":{\"type\":\"Object\",\"defaultValue\":\"datafpherwjqvsw\"},\"c\":{\"type\":\"Object\",\"defaultValue\":\"datanuvqkrrsguog\"}},\"annotations\":[\"datatpyabensjflwp\",\"datatvvqtmvifgcvsim\",\"datalbmti\",\"dataxgosnxa\"],\"folder\":{\"name\":\"cdfmzxaoxlhmvjc\"},\"\":{\"xh\":\"datasbnuc\",\"nkleldk\":\"dataaqoqbvejoysoxovl\",\"qrykkxakruupti\":\"datadlqqhn\"}}")
.toObject(AzurePostgreSqlTableDataset.class);
- Assertions.assertEquals("rd", model.description());
- Assertions.assertEquals("veyfbkqynlzxeme", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("vrkkfcwxizkstxne").type());
- Assertions.assertEquals("llfkchhgs", model.folder().name());
+ Assertions.assertEquals("lbh", model.description());
+ Assertions.assertEquals("hovtuercp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("uapasizzfmugykw").type());
+ Assertions.assertEquals("cdfmzxaoxlhmvjc", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzurePostgreSqlTableDataset model = new AzurePostgreSqlTableDataset().withDescription("rd")
- .withStructure("datantpfxxgjahyxfw")
- .withSchema("datat")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("veyfbkqynlzxeme")
- .withParameters(mapOf("ehdmvfoyrxxxff", "datajck", "cgcsapvbcqpf", "datamcuanszeerv", "vpyr",
- "datasekijhminenkb", "fvvcwvurkmjufa", "datavorlfqmljewyn")))
- .withParameters(mapOf("vrkkfcwxizkstxne",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("databsotmynklnmrznm"),
- "tc", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataipx"),
- "tvsayyaeiiv",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataiuvnfaz"),
- "xqetxtdqius",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqtjwrvewojoq")))
- .withAnnotations(Arrays.asList("datazljvgjijzqjhljsa", "datamjsisfqqhc", "dataecagsbfeiirpn"))
- .withFolder(new DatasetFolder().withName("llfkchhgs"))
- .withTableName("datarllld")
- .withTable("datanbdzwils")
- .withSchemaTypePropertiesSchema("datayiqjz");
+ AzurePostgreSqlTableDataset model = new AzurePostgreSqlTableDataset().withDescription("lbh")
+ .withStructure("datapduibsr")
+ .withSchema("dataqnneqrypyurvs")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hovtuercp")
+ .withParameters(mapOf("yb", "datawc", "nwczsraz", "datadzycxhaoegjzgplj")))
+ .withParameters(mapOf("uapasizzfmugykw",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datacqhxhj"),
+ "enndzgthdzit", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datauo"),
+ "wonadezmzxvfybxm",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datafpherwjqvsw"), "c",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datanuvqkrrsguog")))
+ .withAnnotations(Arrays.asList("datatpyabensjflwp", "datatvvqtmvifgcvsim", "datalbmti", "dataxgosnxa"))
+ .withFolder(new DatasetFolder().withName("cdfmzxaoxlhmvjc"))
+ .withTableName("datascec")
+ .withTable("dataaajdfwrdkql")
+ .withSchemaTypePropertiesSchema("datakfekdesbpjq");
model = BinaryData.fromObject(model).toObject(AzurePostgreSqlTableDataset.class);
- Assertions.assertEquals("rd", model.description());
- Assertions.assertEquals("veyfbkqynlzxeme", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("vrkkfcwxizkstxne").type());
- Assertions.assertEquals("llfkchhgs", model.folder().name());
+ Assertions.assertEquals("lbh", model.description());
+ Assertions.assertEquals("hovtuercp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("uapasizzfmugykw").type());
+ Assertions.assertEquals("cdfmzxaoxlhmvjc", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTypePropertiesTests.java
index 92b6c5153b53..9d5fad721f3b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzurePostgreSqlTableDatasetTypePropertiesTests.java
@@ -11,16 +11,16 @@ public final class AzurePostgreSqlTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzurePostgreSqlTableDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"datazx\",\"table\":\"datads\",\"schema\":\"databfjilbuazccouhw\"}")
+ .fromString("{\"tableName\":\"datagvpzgy\",\"table\":\"datacnpxiema\",\"schema\":\"dataztjekxsnnbrys\"}")
.toObject(AzurePostgreSqlTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzurePostgreSqlTableDatasetTypeProperties model
- = new AzurePostgreSqlTableDatasetTypeProperties().withTableName("datazx")
- .withTable("datads")
- .withSchema("databfjilbuazccouhw");
+ = new AzurePostgreSqlTableDatasetTypeProperties().withTableName("datagvpzgy")
+ .withTable("datacnpxiema")
+ .withSchema("dataztjekxsnnbrys");
model = BinaryData.fromObject(model).toObject(AzurePostgreSqlTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureQueueSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureQueueSinkTests.java
index fc331fce6a55..7bf1f7a01582 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureQueueSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureQueueSinkTests.java
@@ -11,18 +11,18 @@ public final class AzureQueueSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureQueueSink model = BinaryData.fromString(
- "{\"type\":\"AzureQueueSink\",\"writeBatchSize\":\"datagows\",\"writeBatchTimeout\":\"dataguap\",\"sinkRetryCount\":\"datalhhmby\",\"sinkRetryWait\":\"datacexpopqy\",\"maxConcurrentConnections\":\"datacesqpvmoxil\",\"disableMetricsCollection\":\"datakqiqsriubem\",\"\":{\"htkyzsgayngmowv\":\"dataygmrenrbngcafmo\",\"hysuapdns\":\"datanvfgqx\",\"mggy\":\"dataroqxrvycjdni\"}}")
+ "{\"type\":\"AzureQueueSink\",\"writeBatchSize\":\"datajfkaoew\",\"writeBatchTimeout\":\"datayizdglzz\",\"sinkRetryCount\":\"datafi\",\"sinkRetryWait\":\"datavyxyrykn\",\"maxConcurrentConnections\":\"datatjgpyvjgsjyjnhwb\",\"disableMetricsCollection\":\"datawrncxw\",\"\":{\"pb\":\"datarrvpamfpini\"}}")
.toObject(AzureQueueSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureQueueSink model = new AzureQueueSink().withWriteBatchSize("datagows")
- .withWriteBatchTimeout("dataguap")
- .withSinkRetryCount("datalhhmby")
- .withSinkRetryWait("datacexpopqy")
- .withMaxConcurrentConnections("datacesqpvmoxil")
- .withDisableMetricsCollection("datakqiqsriubem");
+ AzureQueueSink model = new AzureQueueSink().withWriteBatchSize("datajfkaoew")
+ .withWriteBatchTimeout("datayizdglzz")
+ .withSinkRetryCount("datafi")
+ .withSinkRetryWait("datavyxyrykn")
+ .withMaxConcurrentConnections("datatjgpyvjgsjyjnhwb")
+ .withDisableMetricsCollection("datawrncxw");
model = BinaryData.fromObject(model).toObject(AzureQueueSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTests.java
index dca3a1670628..302080fcf14f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTests.java
@@ -19,36 +19,37 @@ public final class AzureSearchIndexDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSearchIndexDataset model = BinaryData.fromString(
- "{\"type\":\"AzureSearchIndex\",\"typeProperties\":{\"indexName\":\"datalivgti\"},\"description\":\"kqjqjcaj\",\"structure\":\"datafytkhhkemrv\",\"schema\":\"dataeoj\",\"linkedServiceName\":{\"referenceName\":\"dyulglhelwr\",\"parameters\":{\"gaex\":\"datafqfxspxgogypbz\",\"mb\":\"datanskvctvuz\",\"cyxrn\":\"datattmhlvr\",\"pdwzjggkwdep\":\"dataukfaj\"}},\"parameters\":{\"gtrttcuayiqylnk\":{\"type\":\"Float\",\"defaultValue\":\"datayfiqiidxcorjvudy\"},\"gqexowq\":{\"type\":\"Object\",\"defaultValue\":\"datazifb\"},\"kuobpw\":{\"type\":\"Array\",\"defaultValue\":\"datagqrqkkvfy\"},\"ewhpnyjt\":{\"type\":\"String\",\"defaultValue\":\"datapgobothx\"}},\"annotations\":[\"datazyvextchslro\",\"datadowuwhdlri\"],\"folder\":{\"name\":\"zttcbiich\"},\"\":{\"ycymzrlcfgdwzauz\":\"datadsozodwjcfqoyxry\",\"ilykqadfgesv\":\"datadheadnyciwz\",\"bri\":\"dataoha\",\"ljqovqmxqsxo\":\"datamadjrsbga\"}}")
+ "{\"type\":\"AzureSearchIndex\",\"typeProperties\":{\"indexName\":\"dataofwuzeb\"},\"description\":\"vmpjbhzyen\",\"structure\":\"datapetxeudwkh\",\"schema\":\"datackdoxo\",\"linkedServiceName\":{\"referenceName\":\"jcdevzpfreor\",\"parameters\":{\"x\":\"datayjmgvrlh\"}},\"parameters\":{\"kdywkszavuafane\":{\"type\":\"Array\",\"defaultValue\":\"datanhbcjy\"},\"zw\":{\"type\":\"Float\",\"defaultValue\":\"datatptplkossjbzvx\"},\"nyuvbtcuhjcgjt\":{\"type\":\"SecureString\",\"defaultValue\":\"datauhfgtiaczhfjdcc\"},\"bszsbzrrxey\":{\"type\":\"Int\",\"defaultValue\":\"datatomnlzthc\"}},\"annotations\":[\"datacowlrmbdctqx\"],\"folder\":{\"name\":\"joezvw\"},\"\":{\"ndm\":\"datazgavp\",\"ek\":\"datafiekkiskyyy\",\"bjiutfofhoajjyl\":\"datafffyshdawjlmlcuf\"}}")
.toObject(AzureSearchIndexDataset.class);
- Assertions.assertEquals("kqjqjcaj", model.description());
- Assertions.assertEquals("dyulglhelwr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("gtrttcuayiqylnk").type());
- Assertions.assertEquals("zttcbiich", model.folder().name());
+ Assertions.assertEquals("vmpjbhzyen", model.description());
+ Assertions.assertEquals("jcdevzpfreor", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("kdywkszavuafane").type());
+ Assertions.assertEquals("joezvw", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSearchIndexDataset model = new AzureSearchIndexDataset().withDescription("kqjqjcaj")
- .withStructure("datafytkhhkemrv")
- .withSchema("dataeoj")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dyulglhelwr")
- .withParameters(mapOf("gaex", "datafqfxspxgogypbz", "mb", "datanskvctvuz", "cyxrn", "datattmhlvr",
- "pdwzjggkwdep", "dataukfaj")))
- .withParameters(mapOf("gtrttcuayiqylnk",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datayfiqiidxcorjvudy"),
- "gqexowq", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datazifb"),
- "kuobpw", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datagqrqkkvfy"),
- "ewhpnyjt",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datapgobothx")))
- .withAnnotations(Arrays.asList("datazyvextchslro", "datadowuwhdlri"))
- .withFolder(new DatasetFolder().withName("zttcbiich"))
- .withIndexName("datalivgti");
+ AzureSearchIndexDataset model = new AzureSearchIndexDataset().withDescription("vmpjbhzyen")
+ .withStructure("datapetxeudwkh")
+ .withSchema("datackdoxo")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("jcdevzpfreor")
+ .withParameters(mapOf("x", "datayjmgvrlh")))
+ .withParameters(mapOf("kdywkszavuafane",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanhbcjy"), "zw",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datatptplkossjbzvx"),
+ "nyuvbtcuhjcgjt",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datauhfgtiaczhfjdcc"),
+ "bszsbzrrxey",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datatomnlzthc")))
+ .withAnnotations(Arrays.asList("datacowlrmbdctqx"))
+ .withFolder(new DatasetFolder().withName("joezvw"))
+ .withIndexName("dataofwuzeb");
model = BinaryData.fromObject(model).toObject(AzureSearchIndexDataset.class);
- Assertions.assertEquals("kqjqjcaj", model.description());
- Assertions.assertEquals("dyulglhelwr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("gtrttcuayiqylnk").type());
- Assertions.assertEquals("zttcbiich", model.folder().name());
+ Assertions.assertEquals("vmpjbhzyen", model.description());
+ Assertions.assertEquals("jcdevzpfreor", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("kdywkszavuafane").type());
+ Assertions.assertEquals("joezvw", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTypePropertiesTests.java
index d247922da0d5..0955650cc2eb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class AzureSearchIndexDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- AzureSearchIndexDatasetTypeProperties model = BinaryData.fromString("{\"indexName\":\"dataxqnkiuokg\"}")
+ AzureSearchIndexDatasetTypeProperties model = BinaryData.fromString("{\"indexName\":\"datayqyjnufzvl\"}")
.toObject(AzureSearchIndexDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureSearchIndexDatasetTypeProperties model
- = new AzureSearchIndexDatasetTypeProperties().withIndexName("dataxqnkiuokg");
+ = new AzureSearchIndexDatasetTypeProperties().withIndexName("datayqyjnufzvl");
model = BinaryData.fromObject(model).toObject(AzureSearchIndexDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexSinkTests.java
index 635eca4337e1..7d7bfbe80231 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSearchIndexSinkTests.java
@@ -13,19 +13,19 @@ public final class AzureSearchIndexSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSearchIndexSink model = BinaryData.fromString(
- "{\"type\":\"AzureSearchIndexSink\",\"writeBehavior\":\"Upload\",\"writeBatchSize\":\"datasdccmdplhzjiqi\",\"writeBatchTimeout\":\"dataiwrhmzkxrqzgshqx\",\"sinkRetryCount\":\"dataunuvfslawimhoaqj\",\"sinkRetryWait\":\"datahlpznmdai\",\"maxConcurrentConnections\":\"datazqz\",\"disableMetricsCollection\":\"datadipnhbsvrlr\",\"\":{\"xtl\":\"datamnoasyyadyf\",\"ekuovwiwtykpr\":\"datanzcmdgsv\"}}")
+ "{\"type\":\"AzureSearchIndexSink\",\"writeBehavior\":\"Upload\",\"writeBatchSize\":\"dataerejrdxhlo\",\"writeBatchTimeout\":\"dataxhztdca\",\"sinkRetryCount\":\"datamvqgqmi\",\"sinkRetryWait\":\"datapa\",\"maxConcurrentConnections\":\"datah\",\"disableMetricsCollection\":\"datacyasz\",\"\":{\"ni\":\"datamtcihupoelj\",\"awbsdeqqbdcbnrg\":\"datayoxajit\",\"mtgtnb\":\"datapnor\",\"rwldeinhnsd\":\"datasopuwesmxodyto\"}}")
.toObject(AzureSearchIndexSink.class);
Assertions.assertEquals(AzureSearchIndexWriteBehaviorType.UPLOAD, model.writeBehavior());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSearchIndexSink model = new AzureSearchIndexSink().withWriteBatchSize("datasdccmdplhzjiqi")
- .withWriteBatchTimeout("dataiwrhmzkxrqzgshqx")
- .withSinkRetryCount("dataunuvfslawimhoaqj")
- .withSinkRetryWait("datahlpznmdai")
- .withMaxConcurrentConnections("datazqz")
- .withDisableMetricsCollection("datadipnhbsvrlr")
+ AzureSearchIndexSink model = new AzureSearchIndexSink().withWriteBatchSize("dataerejrdxhlo")
+ .withWriteBatchTimeout("dataxhztdca")
+ .withSinkRetryCount("datamvqgqmi")
+ .withSinkRetryWait("datapa")
+ .withMaxConcurrentConnections("datah")
+ .withDisableMetricsCollection("datacyasz")
.withWriteBehavior(AzureSearchIndexWriteBehaviorType.UPLOAD);
model = BinaryData.fromObject(model).toObject(AzureSearchIndexSink.class);
Assertions.assertEquals(AzureSearchIndexWriteBehaviorType.UPLOAD, model.writeBehavior());
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTests.java
index 98f1c55be734..627a6e35543d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTests.java
@@ -19,37 +19,39 @@ public final class AzureSqlDWTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSqlDWTableDataset model = BinaryData.fromString(
- "{\"type\":\"AzureSqlDWTable\",\"typeProperties\":{\"tableName\":\"dataqphkv\",\"schema\":\"datazadcrxyla\",\"table\":\"datadtyzvelffohur\"},\"description\":\"hjdfrwpsshrmnk\",\"structure\":\"datalpc\",\"schema\":\"dataogkscxj\",\"linkedServiceName\":{\"referenceName\":\"s\",\"parameters\":{\"qcowscuyfql\":\"dataspoebnx\",\"bqhsujkafu\":\"datam\"}},\"parameters\":{\"svgoocq\":{\"type\":\"Bool\",\"defaultValue\":\"datapwnikxkcajgrbrc\"},\"tm\":{\"type\":\"Bool\",\"defaultValue\":\"datamzlpcx\"},\"zfvwjdthkvpyeyoa\":{\"type\":\"Int\",\"defaultValue\":\"datarqic\"},\"kjr\":{\"type\":\"String\",\"defaultValue\":\"datampnqup\"}},\"annotations\":[\"dataky\"],\"folder\":{\"name\":\"bdx\"},\"\":{\"p\":\"datadcclcvqsr\",\"ry\":\"dataylcvwbzmfx\"}}")
+ "{\"type\":\"AzureSqlDWTable\",\"typeProperties\":{\"tableName\":\"dataync\",\"schema\":\"datau\",\"table\":\"datafstyygjqpulm\"},\"description\":\"gm\",\"structure\":\"dataqmiwxzfvvzucqfg\",\"schema\":\"datajnbxwbmwdukin\",\"linkedServiceName\":{\"referenceName\":\"lxhgdekekzou\",\"parameters\":{\"cgldohgc\":\"datawwpzrd\",\"dqtdnnc\":\"datandxfhhhtes\"}},\"parameters\":{\"dxccyijj\":{\"type\":\"Object\",\"defaultValue\":\"datadshvvf\"},\"ydw\":{\"type\":\"Int\",\"defaultValue\":\"dataijzrqnjxmvvsd\"},\"exqwqnghxnimvy\":{\"type\":\"Object\",\"defaultValue\":\"dataruhhqldrdymnswx\"},\"tnylqu\":{\"type\":\"Object\",\"defaultValue\":\"dataxgunnqgypu\"}},\"annotations\":[\"datamvyumgmmuebsnzn\",\"datagsqufmjxcyo\",\"dataeqcazisvbrqgcy\",\"datapgawepk\"],\"folder\":{\"name\":\"rzp\"},\"\":{\"taflvs\":\"datardtbgblxbuibrvj\"}}")
.toObject(AzureSqlDWTableDataset.class);
- Assertions.assertEquals("hjdfrwpsshrmnk", model.description());
- Assertions.assertEquals("s", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("svgoocq").type());
- Assertions.assertEquals("bdx", model.folder().name());
+ Assertions.assertEquals("gm", model.description());
+ Assertions.assertEquals("lxhgdekekzou", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("dxccyijj").type());
+ Assertions.assertEquals("rzp", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSqlDWTableDataset model = new AzureSqlDWTableDataset().withDescription("hjdfrwpsshrmnk")
- .withStructure("datalpc")
- .withSchema("dataogkscxj")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("s")
- .withParameters(mapOf("qcowscuyfql", "dataspoebnx", "bqhsujkafu", "datam")))
- .withParameters(mapOf("svgoocq",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datapwnikxkcajgrbrc"), "tm",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datamzlpcx"),
- "zfvwjdthkvpyeyoa",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datarqic"), "kjr",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datampnqup")))
- .withAnnotations(Arrays.asList("dataky"))
- .withFolder(new DatasetFolder().withName("bdx"))
- .withTableName("dataqphkv")
- .withSchemaTypePropertiesSchema("datazadcrxyla")
- .withTable("datadtyzvelffohur");
+ AzureSqlDWTableDataset model = new AzureSqlDWTableDataset().withDescription("gm")
+ .withStructure("dataqmiwxzfvvzucqfg")
+ .withSchema("datajnbxwbmwdukin")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lxhgdekekzou")
+ .withParameters(mapOf("cgldohgc", "datawwpzrd", "dqtdnnc", "datandxfhhhtes")))
+ .withParameters(mapOf("dxccyijj",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datadshvvf"), "ydw",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataijzrqnjxmvvsd"),
+ "exqwqnghxnimvy",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataruhhqldrdymnswx"),
+ "tnylqu",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataxgunnqgypu")))
+ .withAnnotations(
+ Arrays.asList("datamvyumgmmuebsnzn", "datagsqufmjxcyo", "dataeqcazisvbrqgcy", "datapgawepk"))
+ .withFolder(new DatasetFolder().withName("rzp"))
+ .withTableName("dataync")
+ .withSchemaTypePropertiesSchema("datau")
+ .withTable("datafstyygjqpulm");
model = BinaryData.fromObject(model).toObject(AzureSqlDWTableDataset.class);
- Assertions.assertEquals("hjdfrwpsshrmnk", model.description());
- Assertions.assertEquals("s", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("svgoocq").type());
- Assertions.assertEquals("bdx", model.folder().name());
+ Assertions.assertEquals("gm", model.description());
+ Assertions.assertEquals("lxhgdekekzou", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("dxccyijj").type());
+ Assertions.assertEquals("rzp", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTypePropertiesTests.java
index 590a5318277a..955c60493965 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlDWTableDatasetTypePropertiesTests.java
@@ -11,16 +11,16 @@ public final class AzureSqlDWTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSqlDWTableDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"datajxlpiy\",\"schema\":\"datanpfydrfb\",\"table\":\"datanyxbyxmk\"}")
+ .fromString("{\"tableName\":\"datajihvfjcqrttjfuq\",\"schema\":\"datafjewfeqbavdo\",\"table\":\"datawy\"}")
.toObject(AzureSqlDWTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureSqlDWTableDatasetTypeProperties model
- = new AzureSqlDWTableDatasetTypeProperties().withTableName("datajxlpiy")
- .withSchema("datanpfydrfb")
- .withTable("datanyxbyxmk");
+ = new AzureSqlDWTableDatasetTypeProperties().withTableName("datajihvfjcqrttjfuq")
+ .withSchema("datafjewfeqbavdo")
+ .withTable("datawy");
model = BinaryData.fromObject(model).toObject(AzureSqlDWTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTests.java
index 5b3a8fb442d7..6b869d88c9a4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTests.java
@@ -19,40 +19,37 @@ public final class AzureSqlMITableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSqlMITableDataset model = BinaryData.fromString(
- "{\"type\":\"AzureSqlMITable\",\"typeProperties\":{\"tableName\":\"datahd\",\"schema\":\"datavhaztkxbivz\",\"table\":\"dataxmbrygmwibiosiq\"},\"description\":\"kqfdqwdrtx\",\"structure\":\"datadaglmrcok\",\"schema\":\"dataert\",\"linkedServiceName\":{\"referenceName\":\"ounzsiywh\",\"parameters\":{\"wt\":\"datamfpopikzebqnnf\",\"jculojhhylx\":\"dataqowsdlkhczygpmg\",\"bybwjmtftcvelnir\":\"dataevfiyymotu\"}},\"parameters\":{\"hfxrt\":{\"type\":\"String\",\"defaultValue\":\"datastpaqpibjgbvswm\"},\"ectcxsfmbzdx\":{\"type\":\"Object\",\"defaultValue\":\"datamsennqfabqcama\"},\"fxuzmsvzyqrbrn\":{\"type\":\"Object\",\"defaultValue\":\"datanbkdnny\"},\"uasnjeglhtrxb\":{\"type\":\"Object\",\"defaultValue\":\"datatlxfikjkxaravw\"}},\"annotations\":[\"datacjcnwjzb\",\"databl\",\"datarnwv\"],\"folder\":{\"name\":\"oq\"},\"\":{\"ooauffhxfqkmwzr\":\"datawwsdsorgfhjxsa\"}}")
+ "{\"type\":\"AzureSqlMITable\",\"typeProperties\":{\"tableName\":\"dataqphkv\",\"schema\":\"datazadcrxyla\",\"table\":\"datadtyzvelffohur\"},\"description\":\"hjdfrwpsshrmnk\",\"structure\":\"datalpc\",\"schema\":\"dataogkscxj\",\"linkedServiceName\":{\"referenceName\":\"s\",\"parameters\":{\"qcowscuyfql\":\"dataspoebnx\",\"bqhsujkafu\":\"datam\"}},\"parameters\":{\"svgoocq\":{\"type\":\"Bool\",\"defaultValue\":\"datapwnikxkcajgrbrc\"},\"tm\":{\"type\":\"Bool\",\"defaultValue\":\"datamzlpcx\"},\"zfvwjdthkvpyeyoa\":{\"type\":\"Int\",\"defaultValue\":\"datarqic\"},\"kjr\":{\"type\":\"String\",\"defaultValue\":\"datampnqup\"}},\"annotations\":[\"dataky\"],\"folder\":{\"name\":\"bdx\"},\"\":{\"p\":\"datadcclcvqsr\",\"ry\":\"dataylcvwbzmfx\"}}")
.toObject(AzureSqlMITableDataset.class);
- Assertions.assertEquals("kqfdqwdrtx", model.description());
- Assertions.assertEquals("ounzsiywh", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("hfxrt").type());
- Assertions.assertEquals("oq", model.folder().name());
+ Assertions.assertEquals("hjdfrwpsshrmnk", model.description());
+ Assertions.assertEquals("s", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("svgoocq").type());
+ Assertions.assertEquals("bdx", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSqlMITableDataset model = new AzureSqlMITableDataset().withDescription("kqfdqwdrtx")
- .withStructure("datadaglmrcok")
- .withSchema("dataert")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ounzsiywh")
- .withParameters(mapOf("wt", "datamfpopikzebqnnf", "jculojhhylx", "dataqowsdlkhczygpmg",
- "bybwjmtftcvelnir", "dataevfiyymotu")))
- .withParameters(mapOf("hfxrt",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datastpaqpibjgbvswm"),
- "ectcxsfmbzdx",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datamsennqfabqcama"),
- "fxuzmsvzyqrbrn",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datanbkdnny"),
- "uasnjeglhtrxb",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datatlxfikjkxaravw")))
- .withAnnotations(Arrays.asList("datacjcnwjzb", "databl", "datarnwv"))
- .withFolder(new DatasetFolder().withName("oq"))
- .withTableName("datahd")
- .withSchemaTypePropertiesSchema("datavhaztkxbivz")
- .withTable("dataxmbrygmwibiosiq");
+ AzureSqlMITableDataset model = new AzureSqlMITableDataset().withDescription("hjdfrwpsshrmnk")
+ .withStructure("datalpc")
+ .withSchema("dataogkscxj")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("s")
+ .withParameters(mapOf("qcowscuyfql", "dataspoebnx", "bqhsujkafu", "datam")))
+ .withParameters(mapOf("svgoocq",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datapwnikxkcajgrbrc"), "tm",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datamzlpcx"),
+ "zfvwjdthkvpyeyoa",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datarqic"), "kjr",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datampnqup")))
+ .withAnnotations(Arrays.asList("dataky"))
+ .withFolder(new DatasetFolder().withName("bdx"))
+ .withTableName("dataqphkv")
+ .withSchemaTypePropertiesSchema("datazadcrxyla")
+ .withTable("datadtyzvelffohur");
model = BinaryData.fromObject(model).toObject(AzureSqlMITableDataset.class);
- Assertions.assertEquals("kqfdqwdrtx", model.description());
- Assertions.assertEquals("ounzsiywh", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("hfxrt").type());
- Assertions.assertEquals("oq", model.folder().name());
+ Assertions.assertEquals("hjdfrwpsshrmnk", model.description());
+ Assertions.assertEquals("s", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("svgoocq").type());
+ Assertions.assertEquals("bdx", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTypePropertiesTests.java
index f569a65c2fb6..7ef02149fe45 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlMITableDatasetTypePropertiesTests.java
@@ -10,17 +10,17 @@
public final class AzureSqlMITableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- AzureSqlMITableDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datayoybm\",\"schema\":\"dataotoc\",\"table\":\"datazdaiovrb\"}")
- .toObject(AzureSqlMITableDatasetTypeProperties.class);
+ AzureSqlMITableDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"datajxlpiy\",\"schema\":\"datanpfydrfb\",\"table\":\"datanyxbyxmk\"}")
+ .toObject(AzureSqlMITableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureSqlMITableDatasetTypeProperties model
- = new AzureSqlMITableDatasetTypeProperties().withTableName("datayoybm")
- .withSchema("dataotoc")
- .withTable("datazdaiovrb");
+ = new AzureSqlMITableDatasetTypeProperties().withTableName("datajxlpiy")
+ .withSchema("datanpfydrfb")
+ .withTable("datanyxbyxmk");
model = BinaryData.fromObject(model).toObject(AzureSqlMITableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlSourceTests.java
index b0a892bb20ca..beab63b951d7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlSourceTests.java
@@ -12,27 +12,27 @@ public final class AzureSqlSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSqlSource model = BinaryData.fromString(
- "{\"type\":\"AzureSqlSource\",\"sqlReaderQuery\":\"dataiob\",\"sqlReaderStoredProcedureName\":\"datatpyemppwkry\",\"storedProcedureParameters\":\"datadqpkqf\",\"isolationLevel\":\"datahoiq\",\"produceAdditionalTypes\":\"databhmy\",\"partitionOption\":\"datagmf\",\"partitionSettings\":{\"partitionColumnName\":\"datanckggwiquka\",\"partitionUpperBound\":\"dataokeolzizfbunzm\",\"partitionLowerBound\":\"datafttmjomuwl\"},\"queryTimeout\":\"datajwkpznsfbi\",\"additionalColumns\":\"datafzgpvdlx\",\"sourceRetryCount\":\"dataotclcuxzllnwmgqc\",\"sourceRetryWait\":\"datagjequox\",\"maxConcurrentConnections\":\"datagfspwhfhdguuvg\",\"disableMetricsCollection\":\"datavz\",\"\":{\"m\":\"dataytqzx\",\"rmeufhkoe\":\"datanwpwrfetjg\"}}")
+ "{\"type\":\"AzureSqlSource\",\"sqlReaderQuery\":\"datamabehrfyskzwt\",\"sqlReaderStoredProcedureName\":\"datazvhz\",\"storedProcedureParameters\":\"datac\",\"isolationLevel\":\"datasoxoavlwwpv\",\"produceAdditionalTypes\":\"datanjwvc\",\"partitionOption\":\"datarqlceflgsndur\",\"partitionSettings\":{\"partitionColumnName\":\"datazjwmwkdehjlozzcw\",\"partitionUpperBound\":\"datauxedpqwz\",\"partitionLowerBound\":\"dataimgbxjgxrhajrub\"},\"queryTimeout\":\"dataucvebdfmdjnfe\",\"additionalColumns\":\"datalp\",\"sourceRetryCount\":\"dataclkbwkmwdrvkb\",\"sourceRetryWait\":\"datavnnvk\",\"maxConcurrentConnections\":\"datazldzzjj\",\"disableMetricsCollection\":\"datahjqengopdvnzn\",\"\":{\"vzmiufbwreawhnz\":\"dataodajxvszd\",\"lesvzdvakqajiant\":\"datasmueedbhn\"}}")
.toObject(AzureSqlSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSqlSource model = new AzureSqlSource().withSourceRetryCount("dataotclcuxzllnwmgqc")
- .withSourceRetryWait("datagjequox")
- .withMaxConcurrentConnections("datagfspwhfhdguuvg")
- .withDisableMetricsCollection("datavz")
- .withQueryTimeout("datajwkpznsfbi")
- .withAdditionalColumns("datafzgpvdlx")
- .withSqlReaderQuery("dataiob")
- .withSqlReaderStoredProcedureName("datatpyemppwkry")
- .withStoredProcedureParameters("datadqpkqf")
- .withIsolationLevel("datahoiq")
- .withProduceAdditionalTypes("databhmy")
- .withPartitionOption("datagmf")
- .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datanckggwiquka")
- .withPartitionUpperBound("dataokeolzizfbunzm")
- .withPartitionLowerBound("datafttmjomuwl"));
+ AzureSqlSource model = new AzureSqlSource().withSourceRetryCount("dataclkbwkmwdrvkb")
+ .withSourceRetryWait("datavnnvk")
+ .withMaxConcurrentConnections("datazldzzjj")
+ .withDisableMetricsCollection("datahjqengopdvnzn")
+ .withQueryTimeout("dataucvebdfmdjnfe")
+ .withAdditionalColumns("datalp")
+ .withSqlReaderQuery("datamabehrfyskzwt")
+ .withSqlReaderStoredProcedureName("datazvhz")
+ .withStoredProcedureParameters("datac")
+ .withIsolationLevel("datasoxoavlwwpv")
+ .withProduceAdditionalTypes("datanjwvc")
+ .withPartitionOption("datarqlceflgsndur")
+ .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datazjwmwkdehjlozzcw")
+ .withPartitionUpperBound("datauxedpqwz")
+ .withPartitionLowerBound("dataimgbxjgxrhajrub"));
model = BinaryData.fromObject(model).toObject(AzureSqlSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTests.java
index f7c0b68f74d9..88afc4d3aa38 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTests.java
@@ -19,37 +19,40 @@ public final class AzureSqlTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSqlTableDataset model = BinaryData.fromString(
- "{\"type\":\"AzureSqlTable\",\"typeProperties\":{\"tableName\":\"datagikesmkwtzg\",\"schema\":\"dataagjhxerxlobkdbtq\",\"table\":\"datammniiqyholhjnskb\"},\"description\":\"icnq\",\"structure\":\"datact\",\"schema\":\"datapblxkrkqgvxrkt\",\"linkedServiceName\":{\"referenceName\":\"cjigcwtspa\",\"parameters\":{\"yy\":\"dataxasevchefpgee\"}},\"parameters\":{\"emwcgimmrim\":{\"type\":\"Int\",\"defaultValue\":\"datal\"},\"ahdkmbjsmihrij\":{\"type\":\"Float\",\"defaultValue\":\"datasqqlonbzaow\"},\"lkvbgukbsv\":{\"type\":\"String\",\"defaultValue\":\"datafsjwfcz\"},\"lxa\":{\"type\":\"Object\",\"defaultValue\":\"dataotygnbknhjg\"}},\"annotations\":[\"dataffaspsdzkucsz\"],\"folder\":{\"name\":\"oaqipmnxclfrs\"},\"\":{\"vwvpuofddtbfme\":\"datanm\",\"oyqxfvgyxz\":\"datajcnginxdvm\",\"zujsjirkrp\":\"dataxynofxlttxoqxtd\",\"tkykpaxnlsfgnys\":\"datakcjhmmofbnivd\"}}")
+ "{\"type\":\"AzureSqlTable\",\"typeProperties\":{\"tableName\":\"datazwahdrdvhaztkxb\",\"schema\":\"datazfgxmbry\",\"table\":\"datawibios\"},\"description\":\"sykqfd\",\"structure\":\"datadrtx\",\"schema\":\"datadaglmrcok\",\"linkedServiceName\":{\"referenceName\":\"zertkounz\",\"parameters\":{\"fpopikzeb\":\"datawhuby\",\"wt\":\"datannf\",\"jculojhhylx\":\"dataqowsdlkhczygpmg\",\"bybwjmtftcvelnir\":\"dataevfiyymotu\"}},\"parameters\":{\"hfxrt\":{\"type\":\"String\",\"defaultValue\":\"datastpaqpibjgbvswm\"},\"ectcxsfmbzdx\":{\"type\":\"Object\",\"defaultValue\":\"datamsennqfabqcama\"},\"fxuzmsvzyqrbrn\":{\"type\":\"Object\",\"defaultValue\":\"datanbkdnny\"},\"uasnjeglhtrxb\":{\"type\":\"Object\",\"defaultValue\":\"datatlxfikjkxaravw\"}},\"annotations\":[\"datacjcnwjzb\",\"databl\",\"datarnwv\"],\"folder\":{\"name\":\"oq\"},\"\":{\"ooauffhxfqkmwzr\":\"datawwsdsorgfhjxsa\"}}")
.toObject(AzureSqlTableDataset.class);
- Assertions.assertEquals("icnq", model.description());
- Assertions.assertEquals("cjigcwtspa", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("emwcgimmrim").type());
- Assertions.assertEquals("oaqipmnxclfrs", model.folder().name());
+ Assertions.assertEquals("sykqfd", model.description());
+ Assertions.assertEquals("zertkounz", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("hfxrt").type());
+ Assertions.assertEquals("oq", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSqlTableDataset model = new AzureSqlTableDataset().withDescription("icnq")
- .withStructure("datact")
- .withSchema("datapblxkrkqgvxrkt")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("cjigcwtspa")
- .withParameters(mapOf("yy", "dataxasevchefpgee")))
- .withParameters(mapOf("emwcgimmrim",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datal"), "ahdkmbjsmihrij",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datasqqlonbzaow"),
- "lkvbgukbsv",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datafsjwfcz"), "lxa",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataotygnbknhjg")))
- .withAnnotations(Arrays.asList("dataffaspsdzkucsz"))
- .withFolder(new DatasetFolder().withName("oaqipmnxclfrs"))
- .withTableName("datagikesmkwtzg")
- .withSchemaTypePropertiesSchema("dataagjhxerxlobkdbtq")
- .withTable("datammniiqyholhjnskb");
+ AzureSqlTableDataset model = new AzureSqlTableDataset().withDescription("sykqfd")
+ .withStructure("datadrtx")
+ .withSchema("datadaglmrcok")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zertkounz")
+ .withParameters(mapOf("fpopikzeb", "datawhuby", "wt", "datannf", "jculojhhylx", "dataqowsdlkhczygpmg",
+ "bybwjmtftcvelnir", "dataevfiyymotu")))
+ .withParameters(mapOf("hfxrt",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datastpaqpibjgbvswm"),
+ "ectcxsfmbzdx",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datamsennqfabqcama"),
+ "fxuzmsvzyqrbrn",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datanbkdnny"),
+ "uasnjeglhtrxb",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datatlxfikjkxaravw")))
+ .withAnnotations(Arrays.asList("datacjcnwjzb", "databl", "datarnwv"))
+ .withFolder(new DatasetFolder().withName("oq"))
+ .withTableName("datazwahdrdvhaztkxb")
+ .withSchemaTypePropertiesSchema("datazfgxmbry")
+ .withTable("datawibios");
model = BinaryData.fromObject(model).toObject(AzureSqlTableDataset.class);
- Assertions.assertEquals("icnq", model.description());
- Assertions.assertEquals("cjigcwtspa", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("emwcgimmrim").type());
- Assertions.assertEquals("oaqipmnxclfrs", model.folder().name());
+ Assertions.assertEquals("sykqfd", model.description());
+ Assertions.assertEquals("zertkounz", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("hfxrt").type());
+ Assertions.assertEquals("oq", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTypePropertiesTests.java
index d411a4ebe622..ef8c513bc1d0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSqlTableDatasetTypePropertiesTests.java
@@ -10,17 +10,16 @@
public final class AzureSqlTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- AzureSqlTableDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"dataccptbzetxygxxice\",\"schema\":\"datavjwyuveox\",\"table\":\"dataz\"}")
- .toObject(AzureSqlTableDatasetTypeProperties.class);
+ AzureSqlTableDatasetTypeProperties model
+ = BinaryData.fromString("{\"tableName\":\"datayoybm\",\"schema\":\"dataotoc\",\"table\":\"datazdaiovrb\"}")
+ .toObject(AzureSqlTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSqlTableDatasetTypeProperties model
- = new AzureSqlTableDatasetTypeProperties().withTableName("dataccptbzetxygxxice")
- .withSchema("datavjwyuveox")
- .withTable("dataz");
+ AzureSqlTableDatasetTypeProperties model = new AzureSqlTableDatasetTypeProperties().withTableName("datayoybm")
+ .withSchema("dataotoc")
+ .withTable("datazdaiovrb");
model = BinaryData.fromObject(model).toObject(AzureSqlTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTests.java
index f9f7d8f6d18c..40b950ad0768 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTests.java
@@ -18,32 +18,32 @@ public final class AzureSynapseArtifactsLinkedServiceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSynapseArtifactsLinkedService model = BinaryData.fromString(
- "{\"type\":\"AzureSynapseArtifacts\",\"typeProperties\":{\"endpoint\":\"dataarjiriccu\",\"authentication\":\"datatjvrzdjg\",\"workspaceResourceId\":\"datafayvbsiaenvpzdbz\"},\"version\":\"zgaujvc\",\"connectVia\":{\"referenceName\":\"fybx\",\"parameters\":{\"efijpjiudnust\":\"dataceomsqarbtrkdn\",\"hbhue\":\"datamoxohgkd\",\"jvfrhyxlwqyo\":\"datauvrlxzq\",\"ernbj\":\"datasq\"}},\"description\":\"gmemky\",\"parameters\":{\"mkchjdxrbbhukx\":{\"type\":\"Array\",\"defaultValue\":\"datax\"}},\"annotations\":[\"datayrbeqpgad\"],\"\":{\"ctoqcezmznoej\":\"dataesgnxdvgxtefvs\",\"jy\":\"dataduyqb\",\"utxas\":\"dataajdpbnbpzxnopr\",\"iihggzqh\":\"dataighcxik\"}}")
+ "{\"type\":\"AzureSynapseArtifacts\",\"typeProperties\":{\"endpoint\":\"datav\",\"authentication\":\"dataujzofyldxk\",\"workspaceResourceId\":\"datavfojcvnhpebuiy\"},\"version\":\"ysgq\",\"connectVia\":{\"referenceName\":\"beauvldb\",\"parameters\":{\"uugdarfumitjai\":\"dataguifqjtoxzxbljpz\",\"y\":\"datasmokfdyb\",\"rwrylcttvxk\":\"databgmjrvrsqrjco\"}},\"description\":\"ffpvvqwvvnxoqaaq\",\"parameters\":{\"cwtszt\":{\"type\":\"Object\",\"defaultValue\":\"datawwtevfeu\"}},\"annotations\":[\"datawvfrymq\",\"datafksqfcxdleo\",\"dataysdgkbax\"],\"\":{\"jjqztrpjmeip\":\"datavtkrqiyuqd\",\"qaavjkrepqasviy\":\"dataotaaqyxkloabco\"}}")
.toObject(AzureSynapseArtifactsLinkedService.class);
- Assertions.assertEquals("zgaujvc", model.version());
- Assertions.assertEquals("fybx", model.connectVia().referenceName());
- Assertions.assertEquals("gmemky", model.description());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("mkchjdxrbbhukx").type());
+ Assertions.assertEquals("ysgq", model.version());
+ Assertions.assertEquals("beauvldb", model.connectVia().referenceName());
+ Assertions.assertEquals("ffpvvqwvvnxoqaaq", model.description());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("cwtszt").type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureSynapseArtifactsLinkedService model = new AzureSynapseArtifactsLinkedService().withVersion("zgaujvc")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("fybx")
- .withParameters(mapOf("efijpjiudnust", "dataceomsqarbtrkdn", "hbhue", "datamoxohgkd", "jvfrhyxlwqyo",
- "datauvrlxzq", "ernbj", "datasq")))
- .withDescription("gmemky")
- .withParameters(mapOf("mkchjdxrbbhukx",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datax")))
- .withAnnotations(Arrays.asList("datayrbeqpgad"))
- .withEndpoint("dataarjiriccu")
- .withAuthentication("datatjvrzdjg")
- .withWorkspaceResourceId("datafayvbsiaenvpzdbz");
+ AzureSynapseArtifactsLinkedService model = new AzureSynapseArtifactsLinkedService().withVersion("ysgq")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("beauvldb")
+ .withParameters(mapOf("uugdarfumitjai", "dataguifqjtoxzxbljpz", "y", "datasmokfdyb", "rwrylcttvxk",
+ "databgmjrvrsqrjco")))
+ .withDescription("ffpvvqwvvnxoqaaq")
+ .withParameters(mapOf("cwtszt",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datawwtevfeu")))
+ .withAnnotations(Arrays.asList("datawvfrymq", "datafksqfcxdleo", "dataysdgkbax"))
+ .withEndpoint("datav")
+ .withAuthentication("dataujzofyldxk")
+ .withWorkspaceResourceId("datavfojcvnhpebuiy");
model = BinaryData.fromObject(model).toObject(AzureSynapseArtifactsLinkedService.class);
- Assertions.assertEquals("zgaujvc", model.version());
- Assertions.assertEquals("fybx", model.connectVia().referenceName());
- Assertions.assertEquals("gmemky", model.description());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("mkchjdxrbbhukx").type());
+ Assertions.assertEquals("ysgq", model.version());
+ Assertions.assertEquals("beauvldb", model.connectVia().referenceName());
+ Assertions.assertEquals("ffpvvqwvvnxoqaaq", model.description());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("cwtszt").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTypePropertiesTests.java
index f2d172454227..0e09367b73d2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureSynapseArtifactsLinkedServiceTypePropertiesTests.java
@@ -11,16 +11,16 @@ public final class AzureSynapseArtifactsLinkedServiceTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureSynapseArtifactsLinkedServiceTypeProperties model = BinaryData.fromString(
- "{\"endpoint\":\"dataitty\",\"authentication\":\"datapfudzntbzg\",\"workspaceResourceId\":\"datawhkwypbqnxpohcr\"}")
+ "{\"endpoint\":\"databvolivianklqclft\",\"authentication\":\"dataeouxpdnl\",\"workspaceResourceId\":\"datanbckohnr\"}")
.toObject(AzureSynapseArtifactsLinkedServiceTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
AzureSynapseArtifactsLinkedServiceTypeProperties model
- = new AzureSynapseArtifactsLinkedServiceTypeProperties().withEndpoint("dataitty")
- .withAuthentication("datapfudzntbzg")
- .withWorkspaceResourceId("datawhkwypbqnxpohcr");
+ = new AzureSynapseArtifactsLinkedServiceTypeProperties().withEndpoint("databvolivianklqclft")
+ .withAuthentication("dataeouxpdnl")
+ .withWorkspaceResourceId("datanbckohnr");
model = BinaryData.fromObject(model).toObject(AzureSynapseArtifactsLinkedServiceTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTests.java
index 901432570063..e822db0e378d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTests.java
@@ -19,32 +19,35 @@ public final class AzureTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureTableDataset model = BinaryData.fromString(
- "{\"type\":\"AzureTable\",\"typeProperties\":{\"tableName\":\"datahblivwehsudym\"},\"description\":\"bhdosmbngkql\",\"structure\":\"datazduvxdmx\",\"schema\":\"dataatmdmn\",\"linkedServiceName\":{\"referenceName\":\"senxoirxyd\",\"parameters\":{\"xznntwgkvyohp\":\"dataploisjkzs\",\"wytb\":\"dataapzupz\",\"mxpqkjnpyriwn\":\"datajzghximkg\",\"xmmqmt\":\"dataot\"}},\"parameters\":{\"onbexft\":{\"type\":\"Array\",\"defaultValue\":\"datarexw\"}},\"annotations\":[\"dataubheeggzgrnqtl\",\"dataozuumr\",\"datagjq\",\"dataacan\"],\"folder\":{\"name\":\"yxzxjmkanbclazof\"},\"\":{\"w\":\"datavtemaspmanydscdk\",\"haahntofelfhpfi\":\"datapwjc\",\"fivsujybsr\":\"dataoskkz\"}}")
+ "{\"type\":\"AzureTable\",\"typeProperties\":{\"tableName\":\"datablxk\"},\"description\":\"qgvxrktjcjigcw\",\"structure\":\"datapanbqxasevc\",\"schema\":\"datafp\",\"linkedServiceName\":{\"referenceName\":\"eedyybruholaem\",\"parameters\":{\"aowcahdkm\":\"dataimmrimaabsqqlonb\",\"zglkvbgu\":\"datajsmihrijezbfsjwf\",\"gnbknhj\":\"databsvbwyot\",\"ffaspsdzkucsz\":\"dataclxaxw\"}},\"parameters\":{\"nxclfrsbzrnmuv\":{\"type\":\"String\",\"defaultValue\":\"dataqip\"},\"bf\":{\"type\":\"Array\",\"defaultValue\":\"datauofdd\"},\"oyqxfvgyxz\":{\"type\":\"Bool\",\"defaultValue\":\"datajcnginxdvm\"},\"dnzujsj\":{\"type\":\"Bool\",\"defaultValue\":\"datanofxlttxoqx\"}},\"annotations\":[\"datarpskcjhmmo\",\"databnivdqtkykp\",\"dataxnlsf\"],\"folder\":{\"name\":\"scaccptbz\"},\"\":{\"xxicee\":\"datay\"}}")
.toObject(AzureTableDataset.class);
- Assertions.assertEquals("bhdosmbngkql", model.description());
- Assertions.assertEquals("senxoirxyd", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("onbexft").type());
- Assertions.assertEquals("yxzxjmkanbclazof", model.folder().name());
+ Assertions.assertEquals("qgvxrktjcjigcw", model.description());
+ Assertions.assertEquals("eedyybruholaem", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("nxclfrsbzrnmuv").type());
+ Assertions.assertEquals("scaccptbz", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureTableDataset model = new AzureTableDataset().withDescription("bhdosmbngkql")
- .withStructure("datazduvxdmx")
- .withSchema("dataatmdmn")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("senxoirxyd")
- .withParameters(mapOf("xznntwgkvyohp", "dataploisjkzs", "wytb", "dataapzupz", "mxpqkjnpyriwn",
- "datajzghximkg", "xmmqmt", "dataot")))
- .withParameters(mapOf("onbexft",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datarexw")))
- .withAnnotations(Arrays.asList("dataubheeggzgrnqtl", "dataozuumr", "datagjq", "dataacan"))
- .withFolder(new DatasetFolder().withName("yxzxjmkanbclazof"))
- .withTableName("datahblivwehsudym");
+ AzureTableDataset model = new AzureTableDataset().withDescription("qgvxrktjcjigcw")
+ .withStructure("datapanbqxasevc")
+ .withSchema("datafp")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("eedyybruholaem")
+ .withParameters(mapOf("aowcahdkm", "dataimmrimaabsqqlonb", "zglkvbgu", "datajsmihrijezbfsjwf",
+ "gnbknhj", "databsvbwyot", "ffaspsdzkucsz", "dataclxaxw")))
+ .withParameters(mapOf("nxclfrsbzrnmuv",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataqip"), "bf",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datauofdd"), "oyqxfvgyxz",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datajcnginxdvm"), "dnzujsj",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datanofxlttxoqx")))
+ .withAnnotations(Arrays.asList("datarpskcjhmmo", "databnivdqtkykp", "dataxnlsf"))
+ .withFolder(new DatasetFolder().withName("scaccptbz"))
+ .withTableName("datablxk");
model = BinaryData.fromObject(model).toObject(AzureTableDataset.class);
- Assertions.assertEquals("bhdosmbngkql", model.description());
- Assertions.assertEquals("senxoirxyd", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("onbexft").type());
- Assertions.assertEquals("yxzxjmkanbclazof", model.folder().name());
+ Assertions.assertEquals("qgvxrktjcjigcw", model.description());
+ Assertions.assertEquals("eedyybruholaem", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("nxclfrsbzrnmuv").type());
+ Assertions.assertEquals("scaccptbz", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTypePropertiesTests.java
index 68684fb96f4a..92f2aad3132e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableDatasetTypePropertiesTests.java
@@ -10,14 +10,13 @@
public final class AzureTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- AzureTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datazzmrgtxdhmfpp\"}")
+ AzureTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datavjwyuveox\"}")
.toObject(AzureTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureTableDatasetTypeProperties model
- = new AzureTableDatasetTypeProperties().withTableName("datazzmrgtxdhmfpp");
+ AzureTableDatasetTypeProperties model = new AzureTableDatasetTypeProperties().withTableName("datavjwyuveox");
model = BinaryData.fromObject(model).toObject(AzureTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableSourceTests.java
index 0168adccf714..632d27b5c5be 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/AzureTableSourceTests.java
@@ -11,20 +11,20 @@ public final class AzureTableSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
AzureTableSource model = BinaryData.fromString(
- "{\"type\":\"AzureTableSource\",\"azureTableSourceQuery\":\"datans\",\"azureTableSourceIgnoreTableNotFound\":\"dataqtmhff\",\"queryTimeout\":\"datanvrdtdl\",\"additionalColumns\":\"datamgghutl\",\"sourceRetryCount\":\"datazzljyog\",\"sourceRetryWait\":\"datawnegpbiuwnxhqelj\",\"maxConcurrentConnections\":\"dataolqdiku\",\"disableMetricsCollection\":\"datacl\",\"\":{\"wnlpbawtp\":\"datahghkf\"}}")
+ "{\"type\":\"AzureTableSource\",\"azureTableSourceQuery\":\"datauybdzrxbckx\",\"azureTableSourceIgnoreTableNotFound\":\"datanzowguirhexj\",\"queryTimeout\":\"datayhmktpy\",\"additionalColumns\":\"dataicpkoam\",\"sourceRetryCount\":\"datadtbaobj\",\"sourceRetryWait\":\"datafkcvhh\",\"maxConcurrentConnections\":\"datavkuuikrsi\",\"disableMetricsCollection\":\"datarwsj\",\"\":{\"jva\":\"dataen\",\"fm\":\"datadqgfvygrfyyknxua\",\"kt\":\"dataynlcimjmurocryfu\"}}")
.toObject(AzureTableSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- AzureTableSource model = new AzureTableSource().withSourceRetryCount("datazzljyog")
- .withSourceRetryWait("datawnegpbiuwnxhqelj")
- .withMaxConcurrentConnections("dataolqdiku")
- .withDisableMetricsCollection("datacl")
- .withQueryTimeout("datanvrdtdl")
- .withAdditionalColumns("datamgghutl")
- .withAzureTableSourceQuery("datans")
- .withAzureTableSourceIgnoreTableNotFound("dataqtmhff");
+ AzureTableSource model = new AzureTableSource().withSourceRetryCount("datadtbaobj")
+ .withSourceRetryWait("datafkcvhh")
+ .withMaxConcurrentConnections("datavkuuikrsi")
+ .withDisableMetricsCollection("datarwsj")
+ .withQueryTimeout("datayhmktpy")
+ .withAdditionalColumns("dataicpkoam")
+ .withAzureTableSourceQuery("datauybdzrxbckx")
+ .withAzureTableSourceIgnoreTableNotFound("datanzowguirhexj");
model = BinaryData.fromObject(model).toObject(AzureTableSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BigDataPoolParametrizationReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BigDataPoolParametrizationReferenceTests.java
index e520368bbc21..bf1e41473cb3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BigDataPoolParametrizationReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BigDataPoolParametrizationReferenceTests.java
@@ -13,7 +13,7 @@ public final class BigDataPoolParametrizationReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BigDataPoolParametrizationReference model
- = BinaryData.fromString("{\"type\":\"BigDataPoolReference\",\"referenceName\":\"datamiivkzgcqy\"}")
+ = BinaryData.fromString("{\"type\":\"BigDataPoolReference\",\"referenceName\":\"datahektw\"}")
.toObject(BigDataPoolParametrizationReference.class);
Assertions.assertEquals(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE, model.type());
}
@@ -22,7 +22,7 @@ public void testDeserialize() throws Exception {
public void testSerialize() throws Exception {
BigDataPoolParametrizationReference model
= new BigDataPoolParametrizationReference().withType(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE)
- .withReferenceName("datamiivkzgcqy");
+ .withReferenceName("datahektw");
model = BinaryData.fromObject(model).toObject(BigDataPoolParametrizationReference.class);
Assertions.assertEquals(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE, model.type());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinaryReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinaryReadSettingsTests.java
index 123534cdfa1a..3dccb5859e0c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinaryReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinaryReadSettingsTests.java
@@ -14,7 +14,7 @@ public final class BinaryReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BinaryReadSettings model = BinaryData.fromString(
- "{\"type\":\"BinaryReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"gsnpv\":\"datanupftek\"}},\"\":{\"ebtjg\":\"datapkooaolthowcs\",\"exar\":\"dataeuimtxmd\",\"ivftl\":\"dataukoir\",\"p\":\"dataskinmxanjguadh\"}}")
+ "{\"type\":\"BinaryReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"ezkpdm\":\"datafpqxse\",\"fekfxmgjywwid\":\"dataowftfrqebrjopot\"}},\"\":{\"isypga\":\"datasdkvhuiadyho\",\"be\":\"datafdwh\",\"njay\":\"datadokuqnkoskf\",\"mbh\":\"datarjee\"}}")
.toObject(BinaryReadSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySinkTests.java
index fb97cc4118e5..67a3cfaeea9a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySinkTests.java
@@ -16,24 +16,23 @@ public final class BinarySinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BinarySink model = BinaryData.fromString(
- "{\"type\":\"BinarySink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datavhddvtnbtv\",\"disableMetricsCollection\":\"datakjfkaoe\",\"copyBehavior\":\"datamyizdglzzaufi\",\"metadata\":[{\"name\":\"dataxyrykngntjgpy\",\"value\":\"datagsjyjnhwbbhw\"},{\"name\":\"datac\",\"value\":\"datazuerrvpamfpin\"}],\"\":{\"lqge\":\"databfkmfbruuh\"}},\"writeBatchSize\":\"datanlbjfsoll\",\"writeBatchTimeout\":\"datau\",\"sinkRetryCount\":\"datanhxrcjshicvr\",\"sinkRetryWait\":\"databgpcal\",\"maxConcurrentConnections\":\"dataxppvp\",\"disableMetricsCollection\":\"datarfshkjgspboae\",\"\":{\"wpubdhqn\":\"dataibrooogijiqw\",\"axiimqnqmbfptz\":\"datarbvruhdjziv\",\"kkzulmqx\":\"dataxmksxxbdtjvvngn\",\"nwij\":\"dataic\"}}")
+ "{\"type\":\"BinarySink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datanyciss\",\"disableMetricsCollection\":\"datapxftyhfc\",\"copyBehavior\":\"dataqsd\",\"metadata\":[{\"name\":\"dataaawry\",\"value\":\"datazs\"},{\"name\":\"datarzt\",\"value\":\"datarysxxa\"}],\"\":{\"ddvnobesowbtnfq\":\"datacighl\",\"hteho\":\"datawcaxj\",\"xofqjninrskq\":\"datacmeuuuajiotl\"}},\"writeBatchSize\":\"dataqtiuve\",\"writeBatchTimeout\":\"datauciwbiwygwpwqu\",\"sinkRetryCount\":\"dataqgslspihuxgvvio\",\"sinkRetryWait\":\"dataoolkmfi\",\"maxConcurrentConnections\":\"datafbbrndaquxvufr\",\"disableMetricsCollection\":\"dataaehssosowav\",\"\":{\"sjxf\":\"dataieyeblkgupgnst\",\"jff\":\"datahioartvkhufktqg\",\"gkokfzt\":\"datatreot\",\"kegyskmh\":\"datavonbtnnwa\"}}")
.toObject(BinarySink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- BinarySink model = new BinarySink().withWriteBatchSize("datanlbjfsoll")
- .withWriteBatchTimeout("datau")
- .withSinkRetryCount("datanhxrcjshicvr")
- .withSinkRetryWait("databgpcal")
- .withMaxConcurrentConnections("dataxppvp")
- .withDisableMetricsCollection("datarfshkjgspboae")
- .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datavhddvtnbtv")
- .withDisableMetricsCollection("datakjfkaoe")
- .withCopyBehavior("datamyizdglzzaufi")
- .withMetadata(
- Arrays.asList(new MetadataItem().withName("dataxyrykngntjgpy").withValue("datagsjyjnhwbbhw"),
- new MetadataItem().withName("datac").withValue("datazuerrvpamfpin")))
+ BinarySink model = new BinarySink().withWriteBatchSize("dataqtiuve")
+ .withWriteBatchTimeout("datauciwbiwygwpwqu")
+ .withSinkRetryCount("dataqgslspihuxgvvio")
+ .withSinkRetryWait("dataoolkmfi")
+ .withMaxConcurrentConnections("datafbbrndaquxvufr")
+ .withDisableMetricsCollection("dataaehssosowav")
+ .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datanyciss")
+ .withDisableMetricsCollection("datapxftyhfc")
+ .withCopyBehavior("dataqsd")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("dataaawry").withValue("datazs"),
+ new MetadataItem().withName("datarzt").withValue("datarysxxa")))
.withAdditionalProperties(mapOf("type", "StoreWriteSettings")));
model = BinaryData.fromObject(model).toObject(BinarySink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySourceTests.java
index 713c0fdc035d..efdaf82b1d0e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BinarySourceTests.java
@@ -16,18 +16,18 @@ public final class BinarySourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BinarySource model = BinaryData.fromString(
- "{\"type\":\"BinarySource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"dataf\",\"disableMetricsCollection\":\"dataaqdswfnomciwhu\",\"\":{\"rpbcgdptfxof\":\"dataihfndsjpuilf\"}},\"formatSettings\":{\"type\":\"BinaryReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"ynttrnksvxim\":\"dataxomnguqwx\",\"iycxuyzrnngnm\":\"datan\"}},\"\":{\"qalwlirapqhsidf\":\"datawfoummdomvditp\",\"tiqbxzeiudog\":\"datasfnoczefgfqxejj\",\"oeomufaza\":\"datafcrb\",\"bsspexejhwpnjc\":\"datawzbew\"}},\"sourceRetryCount\":\"datacj\",\"sourceRetryWait\":\"dataovuvmdzdqtir\",\"maxConcurrentConnections\":\"dataajsrdecbowkhmaff\",\"disableMetricsCollection\":\"datapdnnsujx\",\"\":{\"ykueatztnprnshln\":\"dataqljzkhnca\",\"tjyisjscuwylukt\":\"dataahvlzgsqwiubgb\",\"xrziry\":\"datacuxuxaihheg\",\"mxqvv\":\"datarpjru\"}}")
+ "{\"type\":\"BinarySource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datantsp\",\"disableMetricsCollection\":\"dataumpyytbjbmjbmtx\",\"\":{\"kgeqotvocjktihnw\":\"dataf\",\"mtfnbvtx\":\"datavtrsgf\",\"jxcdhp\":\"dataqlbmiqbdia\",\"qpfynt\":\"datalxwsfdd\"}},\"formatSettings\":{\"type\":\"BinaryReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"hruwizqvgadole\":\"dataurhljjzsj\"}},\"\":{\"tcesvvrab\":\"datalzjhaqxfams\",\"kxa\":\"datayfhzybjrxen\"}},\"sourceRetryCount\":\"databrcydwr\",\"sourceRetryWait\":\"datatanbwxh\",\"maxConcurrentConnections\":\"dataioqhoxcgfyzlui\",\"disableMetricsCollection\":\"datagpghjakzmn\",\"\":{\"pbxvpfyupgo\":\"dataqmajslwmj\",\"frkzgtxwyqkk\":\"datarwpoxuykqyoyjptk\"}}")
.toObject(BinarySource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- BinarySource model = new BinarySource().withSourceRetryCount("datacj")
- .withSourceRetryWait("dataovuvmdzdqtir")
- .withMaxConcurrentConnections("dataajsrdecbowkhmaff")
- .withDisableMetricsCollection("datapdnnsujx")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("dataf")
- .withDisableMetricsCollection("dataaqdswfnomciwhu")
+ BinarySource model = new BinarySource().withSourceRetryCount("databrcydwr")
+ .withSourceRetryWait("datatanbwxh")
+ .withMaxConcurrentConnections("dataioqhoxcgfyzlui")
+ .withDisableMetricsCollection("datagpghjakzmn")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datantsp")
+ .withDisableMetricsCollection("dataumpyytbjbmjbmtx")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
.withFormatSettings(new BinaryReadSettings().withCompressionProperties(
new CompressionReadSettings().withAdditionalProperties(mapOf("type", "CompressionReadSettings"))));
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTests.java
index a69586707560..393935c3281d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTests.java
@@ -5,8 +5,8 @@
package com.azure.resourcemanager.datafactory.generated;
import com.azure.core.util.BinaryData;
-import com.azure.resourcemanager.datafactory.models.BlobEventsTrigger;
import com.azure.resourcemanager.datafactory.models.BlobEventTypes;
+import com.azure.resourcemanager.datafactory.models.BlobEventsTrigger;
import com.azure.resourcemanager.datafactory.models.PipelineReference;
import com.azure.resourcemanager.datafactory.models.TriggerPipelineReference;
import java.util.Arrays;
@@ -18,49 +18,57 @@ public final class BlobEventsTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BlobEventsTrigger model = BinaryData.fromString(
- "{\"type\":\"BlobEventsTrigger\",\"typeProperties\":{\"blobPathBeginsWith\":\"gghwxpgf\",\"blobPathEndsWith\":\"hc\",\"ignoreEmptyBlobs\":true,\"events\":[\"Microsoft.Storage.BlobDeleted\"],\"scope\":\"plpphfe\"},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"wx\",\"name\":\"kpo\"},\"parameters\":{\"hcvssmlw\":\"datagvtjrobo\",\"mu\":\"datadstlxrg\",\"ulwvezthgwqqtb\":\"datahxoldmhypptfpp\",\"yipzehitdqmb\":\"datab\"}},{\"pipelineReference\":{\"referenceName\":\"wuaj\",\"name\":\"tgpz\"},\"parameters\":{\"drkolpnebn\":\"datakcvkm\",\"jdbdjxvcxepjfxcm\":\"dataafvks\"}},{\"pipelineReference\":{\"referenceName\":\"ivwcmtretflirbvq\",\"name\":\"xgzepinyursqfhrz\"},\"parameters\":{\"bwfxssxarxvftlls\":\"datamfipvgmlf\",\"kd\":\"dataqa\",\"cltfkyqyiiujukc\":\"datagr\",\"fpbodswg\":\"datalvptxtycup\"}}],\"description\":\"lmllrxpxsl\",\"runtimeState\":\"Started\",\"annotations\":[\"datacj\",\"datafapouws\",\"datansbdndirdlehjz\",\"datapdwyhggvhcoaoeti\"],\"\":{\"qtfcupjmw\":\"datakeirambfmsaedglu\",\"ujiqmksafjhtl\":\"dataemi\"}}")
+ "{\"type\":\"BlobEventsTrigger\",\"typeProperties\":{\"blobPathBeginsWith\":\"amijgq\",\"blobPathEndsWith\":\"zvvwyhszewh\",\"ignoreEmptyBlobs\":false,\"events\":[\"Microsoft.Storage.BlobCreated\",\"Microsoft.Storage.BlobCreated\",\"Microsoft.Storage.BlobCreated\",\"Microsoft.Storage.BlobDeleted\"],\"scope\":\"kiwytskp\"},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"vwwbxnxlhdindc\",\"name\":\"iq\"},\"parameters\":{\"jli\":\"datay\",\"hcylvjzufznaed\":\"datagkxrevwvjwtf\"}},{\"pipelineReference\":{\"referenceName\":\"uxrufwdbi\",\"name\":\"udphy\"},\"parameters\":{\"wdesyttka\":\"datavopc\",\"cbntnjnkvsnsiphl\":\"datafabt\",\"xtzgxdxq\":\"datawcedzodvz\"}},{\"pipelineReference\":{\"referenceName\":\"uzubntuimi\",\"name\":\"cnubynrhencgfz\"},\"parameters\":{\"dqtchxtbcqjvy\":\"datazu\",\"ioatzmr\":\"dataotxkhyvjomq\"}},{\"pipelineReference\":{\"referenceName\":\"srjjajlr\",\"name\":\"mjrufwqpnmcwesfp\"},\"parameters\":{\"rztwwkvwpbd\":\"datadzkbky\",\"upnfrlygyjrlu\":\"datazdkrmpljzrzv\",\"l\":\"dataigzwhfeq\",\"yzzk\":\"datajl\"}}],\"description\":\"beydjagyksgntg\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datafjbxhna\",\"datagbloeaewidumi\"],\"\":{\"majirnqcbhviqwfc\":\"datacgbyx\",\"bombncjn\":\"dataiyafafoornsktd\",\"qwnt\":\"datakc\",\"ijobcpruommtuca\":\"dataqvlcunnb\"}}")
.toObject(BlobEventsTrigger.class);
- Assertions.assertEquals("lmllrxpxsl", model.description());
- Assertions.assertEquals("wx", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("kpo", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals("gghwxpgf", model.blobPathBeginsWith());
- Assertions.assertEquals("hc", model.blobPathEndsWith());
- Assertions.assertEquals(true, model.ignoreEmptyBlobs());
- Assertions.assertEquals(BlobEventTypes.MICROSOFT_STORAGE_BLOB_DELETED, model.events().get(0));
- Assertions.assertEquals("plpphfe", model.scope());
+ Assertions.assertEquals("beydjagyksgntg", model.description());
+ Assertions.assertEquals("vwwbxnxlhdindc", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("iq", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("amijgq", model.blobPathBeginsWith());
+ Assertions.assertEquals("zvvwyhszewh", model.blobPathEndsWith());
+ Assertions.assertEquals(false, model.ignoreEmptyBlobs());
+ Assertions.assertEquals(BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED, model.events().get(0));
+ Assertions.assertEquals("kiwytskp", model.scope());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- BlobEventsTrigger model = new BlobEventsTrigger().withDescription("lmllrxpxsl")
- .withAnnotations(Arrays.asList("datacj", "datafapouws", "datansbdndirdlehjz", "datapdwyhggvhcoaoeti"))
- .withPipelines(Arrays.asList(
- new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("wx").withName("kpo"))
- .withParameters(mapOf("hcvssmlw", "datagvtjrobo", "mu", "datadstlxrg", "ulwvezthgwqqtb",
- "datahxoldmhypptfpp", "yipzehitdqmb", "datab")),
- new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("wuaj").withName("tgpz"))
- .withParameters(mapOf("drkolpnebn", "datakcvkm", "jdbdjxvcxepjfxcm", "dataafvks")),
- new TriggerPipelineReference()
- .withPipelineReference(
- new PipelineReference().withReferenceName("ivwcmtretflirbvq").withName("xgzepinyursqfhrz"))
- .withParameters(mapOf("bwfxssxarxvftlls", "datamfipvgmlf", "kd", "dataqa", "cltfkyqyiiujukc",
- "datagr", "fpbodswg", "datalvptxtycup"))))
- .withBlobPathBeginsWith("gghwxpgf")
- .withBlobPathEndsWith("hc")
- .withIgnoreEmptyBlobs(true)
- .withEvents(Arrays.asList(BlobEventTypes.MICROSOFT_STORAGE_BLOB_DELETED))
- .withScope("plpphfe");
+ BlobEventsTrigger model
+ = new BlobEventsTrigger().withDescription("beydjagyksgntg")
+ .withAnnotations(Arrays.asList("datafjbxhna", "datagbloeaewidumi"))
+ .withPipelines(Arrays.asList(
+ new TriggerPipelineReference()
+ .withPipelineReference(
+ new PipelineReference().withReferenceName("vwwbxnxlhdindc").withName("iq"))
+ .withParameters(mapOf("jli", "datay", "hcylvjzufznaed", "datagkxrevwvjwtf")),
+ new TriggerPipelineReference()
+ .withPipelineReference(new PipelineReference().withReferenceName("uxrufwdbi").withName("udphy"))
+ .withParameters(mapOf("wdesyttka", "datavopc", "cbntnjnkvsnsiphl", "datafabt", "xtzgxdxq",
+ "datawcedzodvz")),
+ new TriggerPipelineReference()
+ .withPipelineReference(
+ new PipelineReference().withReferenceName("uzubntuimi").withName("cnubynrhencgfz"))
+ .withParameters(mapOf("dqtchxtbcqjvy", "datazu", "ioatzmr", "dataotxkhyvjomq")),
+ new TriggerPipelineReference()
+ .withPipelineReference(
+ new PipelineReference().withReferenceName("srjjajlr").withName("mjrufwqpnmcwesfp"))
+ .withParameters(mapOf("rztwwkvwpbd", "datadzkbky", "upnfrlygyjrlu", "datazdkrmpljzrzv", "l",
+ "dataigzwhfeq", "yzzk", "datajl"))))
+ .withBlobPathBeginsWith("amijgq")
+ .withBlobPathEndsWith("zvvwyhszewh")
+ .withIgnoreEmptyBlobs(false)
+ .withEvents(Arrays.asList(BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED,
+ BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED, BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED,
+ BlobEventTypes.MICROSOFT_STORAGE_BLOB_DELETED))
+ .withScope("kiwytskp");
model = BinaryData.fromObject(model).toObject(BlobEventsTrigger.class);
- Assertions.assertEquals("lmllrxpxsl", model.description());
- Assertions.assertEquals("wx", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("kpo", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals("gghwxpgf", model.blobPathBeginsWith());
- Assertions.assertEquals("hc", model.blobPathEndsWith());
- Assertions.assertEquals(true, model.ignoreEmptyBlobs());
- Assertions.assertEquals(BlobEventTypes.MICROSOFT_STORAGE_BLOB_DELETED, model.events().get(0));
- Assertions.assertEquals("plpphfe", model.scope());
+ Assertions.assertEquals("beydjagyksgntg", model.description());
+ Assertions.assertEquals("vwwbxnxlhdindc", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("iq", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("amijgq", model.blobPathBeginsWith());
+ Assertions.assertEquals("zvvwyhszewh", model.blobPathEndsWith());
+ Assertions.assertEquals(false, model.ignoreEmptyBlobs());
+ Assertions.assertEquals(BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED, model.events().get(0));
+ Assertions.assertEquals("kiwytskp", model.scope());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTypePropertiesTests.java
index 83913e73d608..ffc88a8f9041 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobEventsTriggerTypePropertiesTests.java
@@ -14,29 +14,29 @@ public final class BlobEventsTriggerTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BlobEventsTriggerTypeProperties model = BinaryData.fromString(
- "{\"blobPathBeginsWith\":\"kghtsfppjunk\",\"blobPathEndsWith\":\"thkqnyvufvzrqa\",\"ignoreEmptyBlobs\":false,\"events\":[\"Microsoft.Storage.BlobDeleted\",\"Microsoft.Storage.BlobCreated\",\"Microsoft.Storage.BlobCreated\"],\"scope\":\"eeqqetasijiaqqwo\"}")
+ "{\"blobPathBeginsWith\":\"rlvkdaphzemnjast\",\"blobPathEndsWith\":\"zzyqbwimzjh\",\"ignoreEmptyBlobs\":true,\"events\":[\"Microsoft.Storage.BlobDeleted\",\"Microsoft.Storage.BlobCreated\"],\"scope\":\"grakmwyo\"}")
.toObject(BlobEventsTriggerTypeProperties.class);
- Assertions.assertEquals("kghtsfppjunk", model.blobPathBeginsWith());
- Assertions.assertEquals("thkqnyvufvzrqa", model.blobPathEndsWith());
- Assertions.assertEquals(false, model.ignoreEmptyBlobs());
+ Assertions.assertEquals("rlvkdaphzemnjast", model.blobPathBeginsWith());
+ Assertions.assertEquals("zzyqbwimzjh", model.blobPathEndsWith());
+ Assertions.assertEquals(true, model.ignoreEmptyBlobs());
Assertions.assertEquals(BlobEventTypes.MICROSOFT_STORAGE_BLOB_DELETED, model.events().get(0));
- Assertions.assertEquals("eeqqetasijiaqqwo", model.scope());
+ Assertions.assertEquals("grakmwyo", model.scope());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
BlobEventsTriggerTypeProperties model
- = new BlobEventsTriggerTypeProperties().withBlobPathBeginsWith("kghtsfppjunk")
- .withBlobPathEndsWith("thkqnyvufvzrqa")
- .withIgnoreEmptyBlobs(false)
+ = new BlobEventsTriggerTypeProperties().withBlobPathBeginsWith("rlvkdaphzemnjast")
+ .withBlobPathEndsWith("zzyqbwimzjh")
+ .withIgnoreEmptyBlobs(true)
.withEvents(Arrays.asList(BlobEventTypes.MICROSOFT_STORAGE_BLOB_DELETED,
- BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED, BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED))
- .withScope("eeqqetasijiaqqwo");
+ BlobEventTypes.MICROSOFT_STORAGE_BLOB_CREATED))
+ .withScope("grakmwyo");
model = BinaryData.fromObject(model).toObject(BlobEventsTriggerTypeProperties.class);
- Assertions.assertEquals("kghtsfppjunk", model.blobPathBeginsWith());
- Assertions.assertEquals("thkqnyvufvzrqa", model.blobPathEndsWith());
- Assertions.assertEquals(false, model.ignoreEmptyBlobs());
+ Assertions.assertEquals("rlvkdaphzemnjast", model.blobPathBeginsWith());
+ Assertions.assertEquals("zzyqbwimzjh", model.blobPathEndsWith());
+ Assertions.assertEquals(true, model.ignoreEmptyBlobs());
Assertions.assertEquals(BlobEventTypes.MICROSOFT_STORAGE_BLOB_DELETED, model.events().get(0));
- Assertions.assertEquals("eeqqetasijiaqqwo", model.scope());
+ Assertions.assertEquals("grakmwyo", model.scope());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSinkTests.java
index 5e12e8ea6140..1be7e1e78eff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSinkTests.java
@@ -13,25 +13,26 @@ public final class BlobSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BlobSink model = BinaryData.fromString(
- "{\"type\":\"BlobSink\",\"blobWriterOverwriteFiles\":\"datayxtxerxttobosjx\",\"blobWriterDateTimeFormat\":\"dataytten\",\"blobWriterAddHeader\":\"dataditumyycvtya\",\"copyBehavior\":\"datayimhspjqhi\",\"metadata\":[{\"name\":\"dataqvwhjgtbhre\",\"value\":\"datatq\"},{\"name\":\"datapbtqibq\",\"value\":\"dataugcwzgdfdrdxo\"},{\"name\":\"datakgezulnntpbarej\",\"value\":\"datahlxoljbpoeoywykh\"}],\"writeBatchSize\":\"datavwhrivvzr\",\"writeBatchTimeout\":\"datayfrxlsypwu\",\"sinkRetryCount\":\"dataearbbxan\",\"sinkRetryWait\":\"dataiqkjupvidzh\",\"maxConcurrentConnections\":\"datappqcgbp\",\"disableMetricsCollection\":\"datani\",\"\":{\"arjbakpasuugcng\":\"datadlxuptbtl\"}}")
+ "{\"type\":\"BlobSink\",\"blobWriterOverwriteFiles\":\"datajhgqqjmfrm\",\"blobWriterDateTimeFormat\":\"datav\",\"blobWriterAddHeader\":\"databrmmweeuy\",\"copyBehavior\":\"datajhpxjlg\",\"metadata\":[{\"name\":\"datalirnadqeqfxzc\",\"value\":\"datapogrtkditkwoke\"},{\"name\":\"dataeep\",\"value\":\"datacwsyqxfowfnsyy\"},{\"name\":\"datatrwyojhmgvme\",\"value\":\"datajazqlmigkxtgs\"}],\"writeBatchSize\":\"datadnholkoyxmspud\",\"writeBatchTimeout\":\"datawvzunrqvup\",\"sinkRetryCount\":\"datasrnqz\",\"sinkRetryWait\":\"datajwofgzifrm\",\"maxConcurrentConnections\":\"datatilhoy\",\"disableMetricsCollection\":\"datahwaepg\",\"\":{\"rifcqmfv\":\"datarcdtkv\",\"rvwmmuovturdhnn\":\"dataubmhsxtry\",\"vuei\":\"datahrizwmptsygqztn\"}}")
.toObject(BlobSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- BlobSink model = new BlobSink().withWriteBatchSize("datavwhrivvzr")
- .withWriteBatchTimeout("datayfrxlsypwu")
- .withSinkRetryCount("dataearbbxan")
- .withSinkRetryWait("dataiqkjupvidzh")
- .withMaxConcurrentConnections("datappqcgbp")
- .withDisableMetricsCollection("datani")
- .withBlobWriterOverwriteFiles("datayxtxerxttobosjx")
- .withBlobWriterDateTimeFormat("dataytten")
- .withBlobWriterAddHeader("dataditumyycvtya")
- .withCopyBehavior("datayimhspjqhi")
- .withMetadata(Arrays.asList(new MetadataItem().withName("dataqvwhjgtbhre").withValue("datatq"),
- new MetadataItem().withName("datapbtqibq").withValue("dataugcwzgdfdrdxo"),
- new MetadataItem().withName("datakgezulnntpbarej").withValue("datahlxoljbpoeoywykh")));
+ BlobSink model = new BlobSink().withWriteBatchSize("datadnholkoyxmspud")
+ .withWriteBatchTimeout("datawvzunrqvup")
+ .withSinkRetryCount("datasrnqz")
+ .withSinkRetryWait("datajwofgzifrm")
+ .withMaxConcurrentConnections("datatilhoy")
+ .withDisableMetricsCollection("datahwaepg")
+ .withBlobWriterOverwriteFiles("datajhgqqjmfrm")
+ .withBlobWriterDateTimeFormat("datav")
+ .withBlobWriterAddHeader("databrmmweeuy")
+ .withCopyBehavior("datajhpxjlg")
+ .withMetadata(
+ Arrays.asList(new MetadataItem().withName("datalirnadqeqfxzc").withValue("datapogrtkditkwoke"),
+ new MetadataItem().withName("dataeep").withValue("datacwsyqxfowfnsyy"),
+ new MetadataItem().withName("datatrwyojhmgvme").withValue("datajazqlmigkxtgs")));
model = BinaryData.fromObject(model).toObject(BlobSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSourceTests.java
index 54bbd4f160c4..67885e2a8983 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobSourceTests.java
@@ -11,19 +11,19 @@ public final class BlobSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BlobSource model = BinaryData.fromString(
- "{\"type\":\"BlobSource\",\"treatEmptyAsNull\":\"datakiw\",\"skipHeaderLineCount\":\"dataplqnilozf\",\"recursive\":\"datavsf\",\"sourceRetryCount\":\"datacarfdmlie\",\"sourceRetryWait\":\"datawocufcshqfc\",\"maxConcurrentConnections\":\"datanxfof\",\"disableMetricsCollection\":\"datadroqktegi\",\"\":{\"lzvgjme\":\"datazctqbvn\",\"yislepdb\":\"dataqoy\",\"pfnumpyy\":\"dataiklnt\",\"bmjbmtxbi\":\"datab\"}}")
+ "{\"type\":\"BlobSource\",\"treatEmptyAsNull\":\"datazuzvbqbroyrw\",\"skipHeaderLineCount\":\"databbfweozkbok\",\"recursive\":\"datasu\",\"sourceRetryCount\":\"datacslzca\",\"sourceRetryWait\":\"datad\",\"maxConcurrentConnections\":\"datafwkpupbsgfnqtxl\",\"disableMetricsCollection\":\"dataoviklxsgstunsatc\",\"\":{\"tgsazwx\":\"datadbehkbuajkodpz\",\"hasjbuhz\":\"datafaas\"}}")
.toObject(BlobSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- BlobSource model = new BlobSource().withSourceRetryCount("datacarfdmlie")
- .withSourceRetryWait("datawocufcshqfc")
- .withMaxConcurrentConnections("datanxfof")
- .withDisableMetricsCollection("datadroqktegi")
- .withTreatEmptyAsNull("datakiw")
- .withSkipHeaderLineCount("dataplqnilozf")
- .withRecursive("datavsf");
+ BlobSource model = new BlobSource().withSourceRetryCount("datacslzca")
+ .withSourceRetryWait("datad")
+ .withMaxConcurrentConnections("datafwkpupbsgfnqtxl")
+ .withDisableMetricsCollection("dataoviklxsgstunsatc")
+ .withTreatEmptyAsNull("datazuzvbqbroyrw")
+ .withSkipHeaderLineCount("databbfweozkbok")
+ .withRecursive("datasu");
model = BinaryData.fromObject(model).toObject(BlobSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTests.java
index 186550202ceb..04cefb8ce0a9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTests.java
@@ -18,47 +18,35 @@ public final class BlobTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BlobTrigger model = BinaryData.fromString(
- "{\"type\":\"BlobTrigger\",\"typeProperties\":{\"folderPath\":\"ym\",\"maxConcurrency\":1812804884,\"linkedService\":{\"referenceName\":\"ztorvwgpjxdii\",\"parameters\":{\"txzvyd\":\"datadzhkbcouavotfm\",\"bjcznx\":\"dataqmlkrxjqp\",\"yu\":\"datahiwaau\",\"onrrarznlr\":\"datajirtiubvyudk\"}}},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"xaejbmtou\",\"name\":\"udfhclssedxiigw\"},\"parameters\":{\"vsjaaeds\":\"dataqjpudupish\"}},{\"pipelineReference\":{\"referenceName\":\"dulndywghnptfvol\",\"name\":\"romhsias\"},\"parameters\":{\"kwc\":\"datapelq\",\"xhoqfvuqimdgk\":\"datapmsyhrvifurg\",\"iipnszrrmq\":\"datafghc\"}},{\"pipelineReference\":{\"referenceName\":\"xyawtdsnvxhx\",\"name\":\"decryoffglwmkmb\"},\"parameters\":{\"qicehx\":\"datanxlqnzxsdbfb\",\"ducozdz\":\"dataztffng\",\"bj\":\"datahtfmgpioxzh\"}}],\"description\":\"u\",\"runtimeState\":\"Disabled\",\"annotations\":[\"dataohaeeuotfavmdpep\",\"dataycvwew\",\"datagnpu\",\"datapaqj\"],\"\":{\"xuxregfb\":\"datavjwlrit\",\"mjgtjckf\":\"datafkzpf\",\"xmmpuksvoimdg\":\"dataljrlrkvhgnm\"}}")
+ "{\"type\":\"BlobTrigger\",\"typeProperties\":{\"folderPath\":\"axcbfrnttlrumv\",\"maxConcurrency\":1631960216,\"linkedService\":{\"referenceName\":\"byedcavv\",\"parameters\":{\"mqxbauzvxe\":\"datannhafed\"}}},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"mg\",\"name\":\"vmuqxsoc\"},\"parameters\":{\"jpu\":\"datartcifxle\",\"cvsjcdmnvtpb\":\"dataai\",\"wcbnm\":\"datahzcaaqvsdaqfvplf\",\"bbvqsqw\":\"datashmqn\"}}],\"description\":\"xtqdtvejilq\",\"runtimeState\":\"Stopped\",\"annotations\":[\"datarokfyddrsa\"],\"\":{\"vbc\":\"datanweiytkeqjviaws\",\"lmiuprfqyrwtdnr\":\"dataahe\"}}")
.toObject(BlobTrigger.class);
- Assertions.assertEquals("u", model.description());
- Assertions.assertEquals("xaejbmtou", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("udfhclssedxiigw", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals("ym", model.folderPath());
- Assertions.assertEquals(1812804884, model.maxConcurrency());
- Assertions.assertEquals("ztorvwgpjxdii", model.linkedService().referenceName());
+ Assertions.assertEquals("xtqdtvejilq", model.description());
+ Assertions.assertEquals("mg", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("vmuqxsoc", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("axcbfrnttlrumv", model.folderPath());
+ Assertions.assertEquals(1631960216, model.maxConcurrency());
+ Assertions.assertEquals("byedcavv", model.linkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- BlobTrigger model = new BlobTrigger().withDescription("u")
- .withAnnotations(Arrays.asList("dataohaeeuotfavmdpep", "dataycvwew", "datagnpu", "datapaqj"))
- .withPipelines(Arrays.asList(
- new TriggerPipelineReference()
- .withPipelineReference(
- new PipelineReference().withReferenceName("xaejbmtou").withName("udfhclssedxiigw"))
- .withParameters(mapOf("vsjaaeds", "dataqjpudupish")),
- new TriggerPipelineReference()
- .withPipelineReference(
- new PipelineReference().withReferenceName("dulndywghnptfvol").withName("romhsias"))
- .withParameters(
- mapOf("kwc", "datapelq", "xhoqfvuqimdgk", "datapmsyhrvifurg", "iipnszrrmq", "datafghc")),
- new TriggerPipelineReference()
- .withPipelineReference(
- new PipelineReference().withReferenceName("xyawtdsnvxhx").withName("decryoffglwmkmb"))
- .withParameters(
- mapOf("qicehx", "datanxlqnzxsdbfb", "ducozdz", "dataztffng", "bj", "datahtfmgpioxzh"))))
- .withFolderPath("ym")
- .withMaxConcurrency(1812804884)
- .withLinkedService(new LinkedServiceReference().withReferenceName("ztorvwgpjxdii")
- .withParameters(mapOf("txzvyd", "datadzhkbcouavotfm", "bjcznx", "dataqmlkrxjqp", "yu", "datahiwaau",
- "onrrarznlr", "datajirtiubvyudk")));
+ BlobTrigger model = new BlobTrigger().withDescription("xtqdtvejilq")
+ .withAnnotations(Arrays.asList("datarokfyddrsa"))
+ .withPipelines(Arrays.asList(new TriggerPipelineReference()
+ .withPipelineReference(new PipelineReference().withReferenceName("mg").withName("vmuqxsoc"))
+ .withParameters(mapOf("jpu", "datartcifxle", "cvsjcdmnvtpb", "dataai", "wcbnm", "datahzcaaqvsdaqfvplf",
+ "bbvqsqw", "datashmqn"))))
+ .withFolderPath("axcbfrnttlrumv")
+ .withMaxConcurrency(1631960216)
+ .withLinkedService(new LinkedServiceReference().withReferenceName("byedcavv")
+ .withParameters(mapOf("mqxbauzvxe", "datannhafed")));
model = BinaryData.fromObject(model).toObject(BlobTrigger.class);
- Assertions.assertEquals("u", model.description());
- Assertions.assertEquals("xaejbmtou", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("udfhclssedxiigw", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals("ym", model.folderPath());
- Assertions.assertEquals(1812804884, model.maxConcurrency());
- Assertions.assertEquals("ztorvwgpjxdii", model.linkedService().referenceName());
+ Assertions.assertEquals("xtqdtvejilq", model.description());
+ Assertions.assertEquals("mg", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("vmuqxsoc", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("axcbfrnttlrumv", model.folderPath());
+ Assertions.assertEquals(1631960216, model.maxConcurrency());
+ Assertions.assertEquals("byedcavv", model.linkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTypePropertiesTests.java
index 56b76e675d92..eb77d9474236 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/BlobTriggerTypePropertiesTests.java
@@ -15,23 +15,24 @@ public final class BlobTriggerTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
BlobTriggerTypeProperties model = BinaryData.fromString(
- "{\"folderPath\":\"fp\",\"maxConcurrency\":1551794950,\"linkedService\":{\"referenceName\":\"kieom\",\"parameters\":{\"zd\":\"databmwitnihwl\"}}}")
+ "{\"folderPath\":\"rmhewdfua\",\"maxConcurrency\":1306502182,\"linkedService\":{\"referenceName\":\"kfojn\",\"parameters\":{\"oprkpdghqsatbebx\":\"datatuyim\",\"zqaavxxvl\":\"dataedyyengnhoxbp\",\"ihqw\":\"dataspptxdra\",\"yguqsqobrent\":\"datartbvqtogkxdevkn\"}}}")
.toObject(BlobTriggerTypeProperties.class);
- Assertions.assertEquals("fp", model.folderPath());
- Assertions.assertEquals(1551794950, model.maxConcurrency());
- Assertions.assertEquals("kieom", model.linkedService().referenceName());
+ Assertions.assertEquals("rmhewdfua", model.folderPath());
+ Assertions.assertEquals(1306502182, model.maxConcurrency());
+ Assertions.assertEquals("kfojn", model.linkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- BlobTriggerTypeProperties model = new BlobTriggerTypeProperties().withFolderPath("fp")
- .withMaxConcurrency(1551794950)
- .withLinkedService(
- new LinkedServiceReference().withReferenceName("kieom").withParameters(mapOf("zd", "databmwitnihwl")));
+ BlobTriggerTypeProperties model = new BlobTriggerTypeProperties().withFolderPath("rmhewdfua")
+ .withMaxConcurrency(1306502182)
+ .withLinkedService(new LinkedServiceReference().withReferenceName("kfojn")
+ .withParameters(mapOf("oprkpdghqsatbebx", "datatuyim", "zqaavxxvl", "dataedyyengnhoxbp", "ihqw",
+ "dataspptxdra", "yguqsqobrent", "datartbvqtogkxdevkn")));
model = BinaryData.fromObject(model).toObject(BlobTriggerTypeProperties.class);
- Assertions.assertEquals("fp", model.folderPath());
- Assertions.assertEquals(1551794950, model.maxConcurrency());
- Assertions.assertEquals("kieom", model.linkedService().referenceName());
+ Assertions.assertEquals("rmhewdfua", model.folderPath());
+ Assertions.assertEquals(1306502182, model.maxConcurrency());
+ Assertions.assertEquals("kfojn", model.linkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CassandraSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CassandraSourceTests.java
index 0e13ef95e260..f18715d2dbd4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CassandraSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CassandraSourceTests.java
@@ -13,22 +13,22 @@ public final class CassandraSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CassandraSource model = BinaryData.fromString(
- "{\"type\":\"CassandraSource\",\"query\":\"dataggzdoblpdtcyv\",\"consistencyLevel\":\"LOCAL_SERIAL\",\"queryTimeout\":\"dataop\",\"additionalColumns\":\"datavgfbvrohw\",\"sourceRetryCount\":\"dataxqweyslwlppoh\",\"sourceRetryWait\":\"datafgalexy\",\"maxConcurrentConnections\":\"datagkadtwd\",\"disableMetricsCollection\":\"databjx\",\"\":{\"jkwltnsnhuvmok\":\"dataxcjdobsgvz\",\"dnlodkqrqnkptixa\":\"datahsclpnb\",\"zmhoplqtzgt\":\"dataoyzgaevrygggcc\"}}")
+ "{\"type\":\"CassandraSource\",\"query\":\"dataaomy\",\"consistencyLevel\":\"EACH_QUORUM\",\"queryTimeout\":\"datawdjbyaav\",\"additionalColumns\":\"datasxamncuhxznmak\",\"sourceRetryCount\":\"datahuetztorhue\",\"sourceRetryWait\":\"datayssz\",\"maxConcurrentConnections\":\"dataewjqgzloorh\",\"disableMetricsCollection\":\"dataur\",\"\":{\"nmhvwgchgpbdkqw\":\"datajqpyxiaakgdk\"}}")
.toObject(CassandraSource.class);
- Assertions.assertEquals(CassandraSourceReadConsistencyLevels.LOCAL_SERIAL, model.consistencyLevel());
+ Assertions.assertEquals(CassandraSourceReadConsistencyLevels.EACH_QUORUM, model.consistencyLevel());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CassandraSource model = new CassandraSource().withSourceRetryCount("dataxqweyslwlppoh")
- .withSourceRetryWait("datafgalexy")
- .withMaxConcurrentConnections("datagkadtwd")
- .withDisableMetricsCollection("databjx")
- .withQueryTimeout("dataop")
- .withAdditionalColumns("datavgfbvrohw")
- .withQuery("dataggzdoblpdtcyv")
- .withConsistencyLevel(CassandraSourceReadConsistencyLevels.LOCAL_SERIAL);
+ CassandraSource model = new CassandraSource().withSourceRetryCount("datahuetztorhue")
+ .withSourceRetryWait("datayssz")
+ .withMaxConcurrentConnections("dataewjqgzloorh")
+ .withDisableMetricsCollection("dataur")
+ .withQueryTimeout("datawdjbyaav")
+ .withAdditionalColumns("datasxamncuhxznmak")
+ .withQuery("dataaomy")
+ .withConsistencyLevel(CassandraSourceReadConsistencyLevels.EACH_QUORUM);
model = BinaryData.fromObject(model).toObject(CassandraSource.class);
- Assertions.assertEquals(CassandraSourceReadConsistencyLevels.LOCAL_SERIAL, model.consistencyLevel());
+ Assertions.assertEquals(CassandraSourceReadConsistencyLevels.EACH_QUORUM, model.consistencyLevel());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTests.java
index 7c20c1f8e417..b2a18eb9aae2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTests.java
@@ -17,33 +17,34 @@ public final class ChainingTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ChainingTrigger model = BinaryData.fromString(
- "{\"type\":\"ChainingTrigger\",\"pipeline\":{\"pipelineReference\":{\"referenceName\":\"tbsck\",\"name\":\"gew\"},\"parameters\":{\"j\":\"datauzoxm\",\"gcfvfwwev\":\"dataxbtkzvtiqtgr\"}},\"typeProperties\":{\"dependsOn\":[{\"referenceName\":\"zrhexivqaqzt\",\"name\":\"gblriznr\"}],\"runDimension\":\"qu\"},\"description\":\"l\",\"runtimeState\":\"Stopped\",\"annotations\":[\"dataljlwkjoj\"],\"\":{\"yneyoxj\":\"datanzrjqlqh\"}}")
+ "{\"type\":\"ChainingTrigger\",\"pipeline\":{\"pipelineReference\":{\"referenceName\":\"l\",\"name\":\"pwsa\"},\"parameters\":{\"rwecrvkiaognma\":\"dataefkgjdnzowp\"}},\"typeProperties\":{\"dependsOn\":[{\"referenceName\":\"zjprlqwjwpejts\",\"name\":\"bvjcvwvyc\"},{\"referenceName\":\"nowzcl\",\"name\":\"mdlhxwwhusrod\"}],\"runDimension\":\"omozafwq\"},\"description\":\"cwkwm\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datada\",\"dataxofaq\",\"datassukvsgkzxznctx\",\"datacznszmjz\"],\"\":{\"vxahxyslhxok\":\"datacaqpkpvdii\",\"chduflajsg\":\"dataomakmi\",\"mfir\":\"datatgzcbvxyqprch\",\"aazvmnv\":\"dataoytkkq\"}}")
.toObject(ChainingTrigger.class);
- Assertions.assertEquals("l", model.description());
- Assertions.assertEquals("tbsck", model.pipeline().pipelineReference().referenceName());
- Assertions.assertEquals("gew", model.pipeline().pipelineReference().name());
- Assertions.assertEquals("zrhexivqaqzt", model.dependsOn().get(0).referenceName());
- Assertions.assertEquals("gblriznr", model.dependsOn().get(0).name());
- Assertions.assertEquals("qu", model.runDimension());
+ Assertions.assertEquals("cwkwm", model.description());
+ Assertions.assertEquals("l", model.pipeline().pipelineReference().referenceName());
+ Assertions.assertEquals("pwsa", model.pipeline().pipelineReference().name());
+ Assertions.assertEquals("zjprlqwjwpejts", model.dependsOn().get(0).referenceName());
+ Assertions.assertEquals("bvjcvwvyc", model.dependsOn().get(0).name());
+ Assertions.assertEquals("omozafwq", model.runDimension());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ChainingTrigger model = new ChainingTrigger().withDescription("l")
- .withAnnotations(Arrays.asList("dataljlwkjoj"))
+ ChainingTrigger model = new ChainingTrigger().withDescription("cwkwm")
+ .withAnnotations(Arrays.asList("datada", "dataxofaq", "datassukvsgkzxznctx", "datacznszmjz"))
.withPipeline(new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("tbsck").withName("gew"))
- .withParameters(mapOf("j", "datauzoxm", "gcfvfwwev", "dataxbtkzvtiqtgr")))
+ .withPipelineReference(new PipelineReference().withReferenceName("l").withName("pwsa"))
+ .withParameters(mapOf("rwecrvkiaognma", "dataefkgjdnzowp")))
.withDependsOn(
- Arrays.asList(new PipelineReference().withReferenceName("zrhexivqaqzt").withName("gblriznr")))
- .withRunDimension("qu");
+ Arrays.asList(new PipelineReference().withReferenceName("zjprlqwjwpejts").withName("bvjcvwvyc"),
+ new PipelineReference().withReferenceName("nowzcl").withName("mdlhxwwhusrod")))
+ .withRunDimension("omozafwq");
model = BinaryData.fromObject(model).toObject(ChainingTrigger.class);
- Assertions.assertEquals("l", model.description());
- Assertions.assertEquals("tbsck", model.pipeline().pipelineReference().referenceName());
- Assertions.assertEquals("gew", model.pipeline().pipelineReference().name());
- Assertions.assertEquals("zrhexivqaqzt", model.dependsOn().get(0).referenceName());
- Assertions.assertEquals("gblriznr", model.dependsOn().get(0).name());
- Assertions.assertEquals("qu", model.runDimension());
+ Assertions.assertEquals("cwkwm", model.description());
+ Assertions.assertEquals("l", model.pipeline().pipelineReference().referenceName());
+ Assertions.assertEquals("pwsa", model.pipeline().pipelineReference().name());
+ Assertions.assertEquals("zjprlqwjwpejts", model.dependsOn().get(0).referenceName());
+ Assertions.assertEquals("bvjcvwvyc", model.dependsOn().get(0).name());
+ Assertions.assertEquals("omozafwq", model.runDimension());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTypePropertiesTests.java
index 1ee2c5e4f4e1..ba8ef20b0f95 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChainingTriggerTypePropertiesTests.java
@@ -14,11 +14,11 @@ public final class ChainingTriggerTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ChainingTriggerTypeProperties model = BinaryData.fromString(
- "{\"dependsOn\":[{\"referenceName\":\"ha\",\"name\":\"nqktbgudfcrltcu\"},{\"referenceName\":\"ouxergclm\",\"name\":\"ufqjmylrt\"},{\"referenceName\":\"zyosdv\",\"name\":\"ezee\"}],\"runDimension\":\"uligunwyf\"}")
+ "{\"dependsOn\":[{\"referenceName\":\"zfypdsrfpihvijsj\",\"name\":\"p\"},{\"referenceName\":\"cqb\",\"name\":\"jjfxz\"},{\"referenceName\":\"jduyotqbfqtx\",\"name\":\"uxmegrix\"},{\"referenceName\":\"lbzjlqrp\",\"name\":\"pjstco\"}],\"runDimension\":\"b\"}")
.toObject(ChainingTriggerTypeProperties.class);
- Assertions.assertEquals("ha", model.dependsOn().get(0).referenceName());
- Assertions.assertEquals("nqktbgudfcrltcu", model.dependsOn().get(0).name());
- Assertions.assertEquals("uligunwyf", model.runDimension());
+ Assertions.assertEquals("zfypdsrfpihvijsj", model.dependsOn().get(0).referenceName());
+ Assertions.assertEquals("p", model.dependsOn().get(0).name());
+ Assertions.assertEquals("b", model.runDimension());
}
@org.junit.jupiter.api.Test
@@ -26,13 +26,14 @@ public void testSerialize() throws Exception {
ChainingTriggerTypeProperties model
= new ChainingTriggerTypeProperties()
.withDependsOn(
- Arrays.asList(new PipelineReference().withReferenceName("ha").withName("nqktbgudfcrltcu"),
- new PipelineReference().withReferenceName("ouxergclm").withName("ufqjmylrt"),
- new PipelineReference().withReferenceName("zyosdv").withName("ezee")))
- .withRunDimension("uligunwyf");
+ Arrays.asList(new PipelineReference().withReferenceName("zfypdsrfpihvijsj").withName("p"),
+ new PipelineReference().withReferenceName("cqb").withName("jjfxz"),
+ new PipelineReference().withReferenceName("jduyotqbfqtx").withName("uxmegrix"),
+ new PipelineReference().withReferenceName("lbzjlqrp").withName("pjstco")))
+ .withRunDimension("b");
model = BinaryData.fromObject(model).toObject(ChainingTriggerTypeProperties.class);
- Assertions.assertEquals("ha", model.dependsOn().get(0).referenceName());
- Assertions.assertEquals("nqktbgudfcrltcu", model.dependsOn().get(0).name());
- Assertions.assertEquals("uligunwyf", model.runDimension());
+ Assertions.assertEquals("zfypdsrfpihvijsj", model.dependsOn().get(0).referenceName());
+ Assertions.assertEquals("p", model.dependsOn().get(0).name());
+ Assertions.assertEquals("b", model.runDimension());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesCreateOrUpdateWithResponseMockTests.java
index cb74485b6424..1c0922a92194 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesCreateOrUpdateWithResponseMockTests.java
@@ -34,7 +34,7 @@ public final class ChangeDataCapturesCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"folder\":{\"name\":\"vb\"},\"description\":\"zkhp\",\"sourceConnectionsInfo\":[{\"sourceEntities\":[{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"vlvosbccxbbr\"},\"linkedServiceType\":\"ssl\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{}]}},{\"sourceEntities\":[{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"aspglc\"},\"linkedServiceType\":\"raer\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{},{}]}},{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"gchdqtlbnk\"},\"linkedServiceType\":\"yox\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{}]}}],\"targetConnectionsInfo\":[{\"targetEntities\":[{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"swgpxhs\"},\"linkedServiceType\":\"bbk\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{},{}]},\"dataMapperMappings\":[{},{},{},{}],\"relationships\":[\"dataqyrtbniyspbghnn\",\"datakouvs\",\"datamiq\"]},{\"targetEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"lbriawknncdfc\"},\"linkedServiceType\":\"yulmxonobozg\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{}]},\"dataMapperMappings\":[{},{}],\"relationships\":[\"dataz\",\"datawcruczvdjuxijmaw\"]}],\"policy\":{\"mode\":\"mdfwexnjbdgls\",\"recurrence\":{\"frequency\":\"Second\",\"interval\":1811335760}},\"allowVNetOverride\":true,\"status\":\"qekvjwaqjps\"},\"name\":\"pkgvstwdczxgfvev\",\"type\":\"vkfm\",\"etag\":\"kluewthydgzlwbbf\",\"\":{\"zwioxar\":\"dataoywlvkp\",\"bzekrwpwyiyq\":\"dataxhpufvucnqym\",\"vudmps\":\"datarcsekhuzim\",\"tkpewtbyciedxsey\":\"dataqpraqjscnilpv\"},\"id\":\"hrvembit\"}";
+ = "{\"properties\":{\"folder\":{\"name\":\"hvagrkjepdfsgk\"},\"description\":\"fltgbbxghxa\",\"sourceConnectionsInfo\":[{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"gslllc\"},\"linkedServiceType\":\"hrbqqumttxmgh\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{}]}},{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"ljbtytdx\"},\"linkedServiceType\":\"pjewqgyexrdszp\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{}]}},{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"rutnaavtjhikc\"},\"linkedServiceType\":\"jswhoh\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{},{}]}}],\"targetConnectionsInfo\":[{\"targetEntities\":[{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"j\"},\"linkedServiceType\":\"bpudjhjwxpbwvceu\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{}]},\"dataMapperMappings\":[{},{},{}],\"relationships\":[\"datawb\",\"datansb\"]},{\"targetEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"c\"},\"linkedServiceType\":\"hyjex\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{}]},\"dataMapperMappings\":[{},{}],\"relationships\":[\"datakgrrrkbuiuspbeq\",\"dataqbscahrfhxrvarv\"]}],\"policy\":{\"mode\":\"manq\",\"recurrence\":{\"frequency\":\"Second\",\"interval\":334723435}},\"allowVNetOverride\":true,\"status\":\"hxngqpbbybhjozn\"},\"name\":\"uvqnopupxbviemy\",\"type\":\"jqdk\",\"etag\":\"bfz\",\"\":{\"hkndedhmj\":\"dataqvwzsazfzyrle\"},\"id\":\"jnvkpd\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -45,62 +45,109 @@ public void testCreateOrUpdateWithResponse() throws Exception {
ChangeDataCaptureResource response
= manager.changeDataCaptures()
- .define("ccaqoiifvind")
- .withExistingFactory("aydm", "lpdjtliil")
+ .define("tkojmmcnlsfof")
+ .withExistingFactory("glkvby", "meraegfyrgrlnb")
.withSourceConnectionsInfo(
Arrays
- .asList(new MapperSourceConnectionsInfo()
- .withSourceEntities(Arrays.asList(new MapperTable(), new MapperTable(), new MapperTable()))
- .withConnection(new MapperConnection()
- .withLinkedService(new LinkedServiceReference().withReferenceName("iyngupphvo"))
- .withLinkedServiceType("ocjsadbuvvpdj")
- .withType(ConnectionType.LINKEDSERVICETYPE)
- .withIsInlineDataset(true)
- .withCommonDslConnectorProperties(Arrays.asList(new MapperDslConnectorProperties(),
- new MapperDslConnectorProperties(), new MapperDslConnectorProperties(),
- new MapperDslConnectorProperties())))))
+ .asList(
+ new MapperSourceConnectionsInfo()
+ .withSourceEntities(
+ Arrays.asList(new MapperTable(), new MapperTable(), new MapperTable()))
+ .withConnection(
+ new MapperConnection()
+ .withLinkedService(new LinkedServiceReference().withReferenceName("jxnoqxgfvg"))
+ .withLinkedServiceType("mtnunfjdgfm")
+ .withType(ConnectionType.LINKEDSERVICETYPE)
+ .withIsInlineDataset(true)
+ .withCommonDslConnectorProperties(
+ Arrays.asList(new MapperDslConnectorProperties())))))
.withTargetConnectionsInfo(
Arrays
- .asList(new MapperTargetConnectionsInfo().withTargetEntities(Arrays.asList(new MapperTable()))
- .withConnection(new MapperConnection()
- .withLinkedService(new LinkedServiceReference().withReferenceName("vz"))
- .withLinkedServiceType("dfikduwqkhmabgzc")
- .withType(ConnectionType.LINKEDSERVICETYPE)
- .withIsInlineDataset(false)
- .withCommonDslConnectorProperties(Arrays.asList(new MapperDslConnectorProperties(),
- new MapperDslConnectorProperties())))
- .withDataMapperMappings(Arrays.asList(new DataMapperMapping(), new DataMapperMapping()))
- .withRelationships(
- Arrays.asList("datawfnlpjivtzshuzyy", "dataivr", "dataqiijkvops", "datamtxvnelw"))))
- .withPolicy(new MapperPolicy().withMode("dm")
+ .asList(
+ new MapperTargetConnectionsInfo()
+ .withTargetEntities(Arrays.asList(new MapperTable(), new MapperTable(),
+ new MapperTable(), new MapperTable()))
+ .withConnection(new MapperConnection()
+ .withLinkedService(
+ new LinkedServiceReference().withReferenceName("aeoozjncurnrdye"))
+ .withLinkedServiceType("xk")
+ .withType(ConnectionType.LINKEDSERVICETYPE)
+ .withIsInlineDataset(false)
+ .withCommonDslConnectorProperties(Arrays.asList(new MapperDslConnectorProperties(),
+ new MapperDslConnectorProperties(), new MapperDslConnectorProperties())))
+ .withDataMapperMappings(Arrays.asList(new DataMapperMapping(), new DataMapperMapping(),
+ new DataMapperMapping(), new DataMapperMapping()))
+ .withRelationships(
+ Arrays.asList("datafprqwopjnrafli", "dataqpmdojbm", "datajohu", "datauvnbiujt")),
+ new MapperTargetConnectionsInfo().withTargetEntities(Arrays.asList(new MapperTable()))
+ .withConnection(new MapperConnection()
+ .withLinkedService(new LinkedServiceReference().withReferenceName("wmwiaut"))
+ .withLinkedServiceType("h")
+ .withType(ConnectionType.LINKEDSERVICETYPE)
+ .withIsInlineDataset(true)
+ .withCommonDslConnectorProperties(
+ Arrays.asList(new MapperDslConnectorProperties(),
+ new MapperDslConnectorProperties(), new MapperDslConnectorProperties())))
+ .withDataMapperMappings(Arrays.asList(new DataMapperMapping()))
+ .withRelationships(
+ Arrays.asList("dataeqhqfryfyfubtrta", "datapj", "datafedowcgqc", "datagvqqy")),
+ new MapperTargetConnectionsInfo()
+ .withTargetEntities(Arrays.asList(new MapperTable(), new MapperTable(),
+ new MapperTable(), new MapperTable()))
+ .withConnection(new MapperConnection()
+ .withLinkedService(
+ new LinkedServiceReference().withReferenceName("qnvnetrnwgchvgpu"))
+ .withLinkedServiceType("n")
+ .withType(ConnectionType.LINKEDSERVICETYPE)
+ .withIsInlineDataset(false)
+ .withCommonDslConnectorProperties(Arrays.asList(new MapperDslConnectorProperties(),
+ new MapperDslConnectorProperties(), new MapperDslConnectorProperties())))
+ .withDataMapperMappings(
+ Arrays.asList(new DataMapperMapping(), new DataMapperMapping(),
+ new DataMapperMapping(), new DataMapperMapping()))
+ .withRelationships(Arrays.asList("datamshonnmbaottulk", "datal")),
+ new MapperTargetConnectionsInfo()
+ .withTargetEntities(Arrays.asList(new MapperTable(), new MapperTable()))
+ .withConnection(new MapperConnection()
+ .withLinkedService(new LinkedServiceReference().withReferenceName("zwfukjwvmmya"))
+ .withLinkedServiceType("lpeyiafz")
+ .withType(ConnectionType.LINKEDSERVICETYPE)
+ .withIsInlineDataset(false)
+ .withCommonDslConnectorProperties(
+ Arrays.asList(new MapperDslConnectorProperties())))
+ .withDataMapperMappings(Arrays.asList(new DataMapperMapping()))
+ .withRelationships(Arrays.asList("dataabouerncgvjmk"))))
+ .withPolicy(new MapperPolicy().withMode("qruolmumz")
.withRecurrence(
- new MapperPolicyRecurrence().withFrequency(FrequencyType.SECOND).withInterval(52613163)))
- .withFolder(new ChangeDataCaptureFolder().withName("a"))
- .withDescription("jrznydcslydhp")
+ new MapperPolicyRecurrence().withFrequency(FrequencyType.MINUTE).withInterval(1963137778)))
+ .withFolder(new ChangeDataCaptureFolder().withName("savdijbiu"))
+ .withDescription("w")
.withAllowVNetOverride(false)
- .withStatus("fltuxwfwlf")
- .withIfMatch("reqfp")
+ .withStatus("jdmgzmpbfho")
+ .withIfMatch("jgjl")
.create();
- Assertions.assertEquals("hrvembit", response.id());
- Assertions.assertEquals("vb", response.folder().name());
- Assertions.assertEquals("zkhp", response.description());
- Assertions.assertEquals("vlvosbccxbbr",
+ Assertions.assertEquals("jnvkpd", response.id());
+ Assertions.assertEquals("hvagrkjepdfsgk", response.folder().name());
+ Assertions.assertEquals("fltgbbxghxa", response.description());
+ Assertions.assertEquals("gslllc",
response.sourceConnectionsInfo().get(0).connection().linkedService().referenceName());
- Assertions.assertEquals("ssl", response.sourceConnectionsInfo().get(0).connection().linkedServiceType());
+ Assertions.assertEquals("hrbqqumttxmgh",
+ response.sourceConnectionsInfo().get(0).connection().linkedServiceType());
Assertions.assertEquals(ConnectionType.LINKEDSERVICETYPE,
response.sourceConnectionsInfo().get(0).connection().type());
Assertions.assertEquals(true, response.sourceConnectionsInfo().get(0).connection().isInlineDataset());
- Assertions.assertEquals("swgpxhs",
+ Assertions.assertEquals("j",
response.targetConnectionsInfo().get(0).connection().linkedService().referenceName());
- Assertions.assertEquals("bbk", response.targetConnectionsInfo().get(0).connection().linkedServiceType());
+ Assertions.assertEquals("bpudjhjwxpbwvceu",
+ response.targetConnectionsInfo().get(0).connection().linkedServiceType());
Assertions.assertEquals(ConnectionType.LINKEDSERVICETYPE,
response.targetConnectionsInfo().get(0).connection().type());
- Assertions.assertEquals(false, response.targetConnectionsInfo().get(0).connection().isInlineDataset());
- Assertions.assertEquals("mdfwexnjbdgls", response.policy().mode());
+ Assertions.assertEquals(true, response.targetConnectionsInfo().get(0).connection().isInlineDataset());
+ Assertions.assertEquals("manq", response.policy().mode());
Assertions.assertEquals(FrequencyType.SECOND, response.policy().recurrence().frequency());
- Assertions.assertEquals(1811335760, response.policy().recurrence().interval());
+ Assertions.assertEquals(334723435, response.policy().recurrence().interval());
Assertions.assertEquals(true, response.allowVNetOverride());
- Assertions.assertEquals("qekvjwaqjps", response.status());
+ Assertions.assertEquals("hxngqpbbybhjozn", response.status());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesDeleteWithResponseMockTests.java
index ce578d7dd1cf..8170931523cb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesDeleteWithResponseMockTests.java
@@ -27,8 +27,7 @@ public void testDeleteWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.changeDataCaptures()
- .deleteWithResponse("chiz", "icxlmymncuhqet", "pqcxrwtygbqowrtn", com.azure.core.util.Context.NONE);
+ manager.changeDataCaptures().deleteWithResponse("v", "pzvrtuaapyejbs", "ec", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesGetWithResponseMockTests.java
index 61b85386119a..86c979428590 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesGetWithResponseMockTests.java
@@ -23,7 +23,7 @@ public final class ChangeDataCapturesGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"folder\":{\"name\":\"wjowgdwc\"},\"description\":\"yyzmxuelpl\",\"sourceConnectionsInfo\":[{\"sourceEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"ldmflngjtltx\"},\"linkedServiceType\":\"byq\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{}]}},{\"sourceEntities\":[{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"ptockgjvflch\"},\"linkedServiceType\":\"b\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{}]}},{\"sourceEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"nlsmfqglvflxltng\"},\"linkedServiceType\":\"lpgclo\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{}]}}],\"targetConnectionsInfo\":[{\"targetEntities\":[{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"fzcymyb\"},\"linkedServiceType\":\"v\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{}]},\"dataMapperMappings\":[{}],\"relationships\":[\"databgitkowflc\",\"dataxqwy\"]},{\"targetEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"qqgaysynejdvt\"},\"linkedServiceType\":\"gwxilbazrui\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{},{}]},\"dataMapperMappings\":[{},{},{}],\"relationships\":[\"dataslylqzw\",\"datalhxgsjzrifgubpn\",\"dataiwlernch\",\"dataxpsonkku\"]},{\"targetEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"zrng\"},\"linkedServiceType\":\"eunp\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{}]},\"dataMapperMappings\":[{}],\"relationships\":[\"datawmqgya\",\"datan\",\"dataxwxnnjvodqne\"]}],\"policy\":{\"mode\":\"y\",\"recurrence\":{\"frequency\":\"Minute\",\"interval\":1237768460}},\"allowVNetOverride\":false,\"status\":\"ngbh\"},\"name\":\"tyvwxc\",\"type\":\"hhzjhmxynszadgv\",\"etag\":\"oxmlb\",\"\":{\"ibqnuhr\":\"datasecwsw\",\"gesaolceb\":\"dataiwnb\",\"olfupxhrl\":\"dataditccuzjlcmzgh\",\"lrcrxxkvuzpsoujc\":\"datatknmp\"},\"id\":\"ubpjwwvies\"}";
+ = "{\"properties\":{\"folder\":{\"name\":\"f\"},\"description\":\"hjlpznxjymdql\",\"sourceConnectionsInfo\":[{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"wltabmcm\"},\"linkedServiceType\":\"e\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{}]}},{\"sourceEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"gfya\"},\"linkedServiceType\":\"pkybgrugklwubkmd\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{},{}]}},{\"sourceEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"mau\"},\"linkedServiceType\":\"rzlfpk\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{}]}}],\"targetConnectionsInfo\":[{\"targetEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"gztxcjnwzvlzwyk\"},\"linkedServiceType\":\"qq\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{}]},\"dataMapperMappings\":[{},{}],\"relationships\":[\"datagivkfhiaa\",\"datalxpwhvu\",\"datahjl\"]},{\"targetEntities\":[{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"nrfuabqotyoa\"},\"linkedServiceType\":\"rlydmldjtrxq\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{}]},\"dataMapperMappings\":[{},{},{}],\"relationships\":[\"dataqajhyufexb\"]},{\"targetEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"ntzjvquwxxouflnc\"},\"linkedServiceType\":\"b\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{}]},\"dataMapperMappings\":[{},{}],\"relationships\":[\"datankrvpkkifjtx\",\"datady\",\"dataymijadh\"]},{\"targetEntities\":[{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"qjqutixykjlypmvo\"},\"linkedServiceType\":\"fnsfbnt\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{}]},\"dataMapperMappings\":[{},{},{}],\"relationships\":[\"dataqddedhkhqwbm\"]}],\"policy\":{\"mode\":\"unxfdpulpnc\",\"recurrence\":{\"frequency\":\"Minute\",\"interval\":874037530}},\"allowVNetOverride\":true,\"status\":\"aeyczb\"},\"name\":\"skpnbdzjuq\",\"type\":\"qyusvgrbaax\",\"etag\":\"tkuchbnydzhafpbc\",\"\":{\"u\":\"datantw\",\"hbumoq\":\"datatffqa\",\"ik\":\"dataaixsalgzzm\",\"nsndcmghddsgjb\":\"datacagmmegukefmujg\"},\"id\":\"z\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -33,28 +33,28 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ChangeDataCaptureResource response = manager.changeDataCaptures()
- .getWithResponse("exdwwraim", "kazamidgoyawgps", "kymm", "imbesgi", com.azure.core.util.Context.NONE)
+ .getWithResponse("uvphkhszesxsyrvj", "wpknbwh", "ev", "own", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("ubpjwwvies", response.id());
- Assertions.assertEquals("wjowgdwc", response.folder().name());
- Assertions.assertEquals("yyzmxuelpl", response.description());
- Assertions.assertEquals("ldmflngjtltx",
+ Assertions.assertEquals("z", response.id());
+ Assertions.assertEquals("f", response.folder().name());
+ Assertions.assertEquals("hjlpznxjymdql", response.description());
+ Assertions.assertEquals("wltabmcm",
response.sourceConnectionsInfo().get(0).connection().linkedService().referenceName());
- Assertions.assertEquals("byq", response.sourceConnectionsInfo().get(0).connection().linkedServiceType());
+ Assertions.assertEquals("e", response.sourceConnectionsInfo().get(0).connection().linkedServiceType());
Assertions.assertEquals(ConnectionType.LINKEDSERVICETYPE,
response.sourceConnectionsInfo().get(0).connection().type());
- Assertions.assertEquals(false, response.sourceConnectionsInfo().get(0).connection().isInlineDataset());
- Assertions.assertEquals("fzcymyb",
+ Assertions.assertEquals(true, response.sourceConnectionsInfo().get(0).connection().isInlineDataset());
+ Assertions.assertEquals("gztxcjnwzvlzwyk",
response.targetConnectionsInfo().get(0).connection().linkedService().referenceName());
- Assertions.assertEquals("v", response.targetConnectionsInfo().get(0).connection().linkedServiceType());
+ Assertions.assertEquals("qq", response.targetConnectionsInfo().get(0).connection().linkedServiceType());
Assertions.assertEquals(ConnectionType.LINKEDSERVICETYPE,
response.targetConnectionsInfo().get(0).connection().type());
- Assertions.assertEquals(false, response.targetConnectionsInfo().get(0).connection().isInlineDataset());
- Assertions.assertEquals("y", response.policy().mode());
+ Assertions.assertEquals(true, response.targetConnectionsInfo().get(0).connection().isInlineDataset());
+ Assertions.assertEquals("unxfdpulpnc", response.policy().mode());
Assertions.assertEquals(FrequencyType.MINUTE, response.policy().recurrence().frequency());
- Assertions.assertEquals(1237768460, response.policy().recurrence().interval());
- Assertions.assertEquals(false, response.allowVNetOverride());
- Assertions.assertEquals("ngbh", response.status());
+ Assertions.assertEquals(874037530, response.policy().recurrence().interval());
+ Assertions.assertEquals(true, response.allowVNetOverride());
+ Assertions.assertEquals("aeyczb", response.status());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesListByFactoryMockTests.java
index c24125d1a4c6..443cf5ad83be 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesListByFactoryMockTests.java
@@ -24,7 +24,7 @@ public final class ChangeDataCapturesListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"folder\":{\"name\":\"rrm\"},\"description\":\"xjwlhulvyz\",\"sourceConnectionsInfo\":[{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"vzq\"},\"linkedServiceType\":\"dkvldrcx\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{},{}]}},{\"sourceEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"qkdtvtpwrmmyao\"},\"linkedServiceType\":\"h\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{}]}}],\"targetConnectionsInfo\":[{\"targetEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"evpmtpqdfpgso\"},\"linkedServiceType\":\"xd\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{}]},\"dataMapperMappings\":[{}],\"relationships\":[\"dataqusg\"]},{\"targetEntities\":[{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"qjh\"},\"linkedServiceType\":\"xnocixvr\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{},{}]},\"dataMapperMappings\":[{}],\"relationships\":[\"datawixtefduqprhz\",\"dataaquhahqt\",\"databbwicteqwjlyn\",\"datarjoydzmbvsl\"]},{\"targetEntities\":[{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"otozxadk\"},\"linkedServiceType\":\"aptv\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{}]},\"dataMapperMappings\":[{},{}],\"relationships\":[\"datapypkfvwlzv\"]}],\"policy\":{\"mode\":\"xvspubfkelqzcpts\",\"recurrence\":{\"frequency\":\"Hour\",\"interval\":1026057080}},\"allowVNetOverride\":true,\"status\":\"fvanpzabbf\"},\"name\":\"issdelyecjmfaf\",\"type\":\"ffyyfthsafvamos\",\"etag\":\"nmcimdtuydynugkj\",\"\":{\"ajjyournxq\":\"datafprfhpcy\",\"mbsghzund\":\"datauzls\"},\"id\":\"bmuvgfkdea\"}]}";
+ = "{\"value\":[{\"properties\":{\"folder\":{\"name\":\"ghnnxkouvsmmi\"},\"description\":\"iigslbriawkn\",\"sourceConnectionsInfo\":[{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"eyulmxonobozge\"},\"linkedServiceType\":\"tcxknipzqwcr\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{},{}]}},{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"maws\"},\"linkedServiceType\":\"dfwex\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{},{},{}]}},{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"oarmlbqekvjwaq\"},\"linkedServiceType\":\"sjrpkgvstwdcz\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{}]}},{\"sourceEntities\":[{}],\"connection\":{\"linkedService\":{\"referenceName\":\"fmytkluewthydgz\"},\"linkedServiceType\":\"bbfun\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{},{},{}]}}],\"targetConnectionsInfo\":[{\"targetEntities\":[{},{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"ioxarwxhpufvuc\"},\"linkedServiceType\":\"ymjbzekrwpwyi\",\"type\":\"linkedservicetype\",\"isInlineDataset\":true,\"commonDslConnectorProperties\":[{},{}]},\"dataMapperMappings\":[{}],\"relationships\":[\"datazimevudmpsu\",\"datapra\",\"datajscni\"]},{\"targetEntities\":[{},{},{}],\"connection\":{\"linkedService\":{\"referenceName\":\"kpewtbyciedxs\"},\"linkedServiceType\":\"jj\",\"type\":\"linkedservicetype\",\"isInlineDataset\":false,\"commonDslConnectorProperties\":[{}]},\"dataMapperMappings\":[{},{},{},{}],\"relationships\":[\"dataaxieuntceekh\",\"dataxgu\",\"datazzcpwbfbfrzr\"]}],\"policy\":{\"mode\":\"ipqbyvesxuzda\",\"recurrence\":{\"frequency\":\"Second\",\"interval\":891591548}},\"allowVNetOverride\":false,\"status\":\"wzjkbaudtpp\"},\"name\":\"qkntnvgwgtgxggm\",\"type\":\"wulqpzqxcyg\",\"etag\":\"gjzrsb\",\"\":{\"cleniozqruqh\":\"datavvbsbkyfbmwzbf\",\"rhgohdv\":\"datapwzhpyymlwalldey\",\"kmqvivps\":\"datahsvrpnoxb\",\"fkjdw\":\"databzrfmfad\"},\"id\":\"yooewyvwwvki\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -34,31 +34,31 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.changeDataCaptures().listByFactory("l", "tdije", com.azure.core.util.Context.NONE);
+ = manager.changeDataCaptures().listByFactory("bkm", "wmmwjugaqyrtbniy", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("bmuvgfkdea", response.iterator().next().id());
- Assertions.assertEquals("rrm", response.iterator().next().folder().name());
- Assertions.assertEquals("xjwlhulvyz", response.iterator().next().description());
- Assertions.assertEquals("vzq",
+ Assertions.assertEquals("yooewyvwwvki", response.iterator().next().id());
+ Assertions.assertEquals("ghnnxkouvsmmi", response.iterator().next().folder().name());
+ Assertions.assertEquals("iigslbriawkn", response.iterator().next().description());
+ Assertions.assertEquals("eyulmxonobozge",
response.iterator().next().sourceConnectionsInfo().get(0).connection().linkedService().referenceName());
- Assertions.assertEquals("dkvldrcx",
+ Assertions.assertEquals("tcxknipzqwcr",
response.iterator().next().sourceConnectionsInfo().get(0).connection().linkedServiceType());
Assertions.assertEquals(ConnectionType.LINKEDSERVICETYPE,
response.iterator().next().sourceConnectionsInfo().get(0).connection().type());
- Assertions.assertEquals(false,
+ Assertions.assertEquals(true,
response.iterator().next().sourceConnectionsInfo().get(0).connection().isInlineDataset());
- Assertions.assertEquals("evpmtpqdfpgso",
+ Assertions.assertEquals("ioxarwxhpufvuc",
response.iterator().next().targetConnectionsInfo().get(0).connection().linkedService().referenceName());
- Assertions.assertEquals("xd",
+ Assertions.assertEquals("ymjbzekrwpwyi",
response.iterator().next().targetConnectionsInfo().get(0).connection().linkedServiceType());
Assertions.assertEquals(ConnectionType.LINKEDSERVICETYPE,
response.iterator().next().targetConnectionsInfo().get(0).connection().type());
Assertions.assertEquals(true,
response.iterator().next().targetConnectionsInfo().get(0).connection().isInlineDataset());
- Assertions.assertEquals("xvspubfkelqzcpts", response.iterator().next().policy().mode());
- Assertions.assertEquals(FrequencyType.HOUR, response.iterator().next().policy().recurrence().frequency());
- Assertions.assertEquals(1026057080, response.iterator().next().policy().recurrence().interval());
- Assertions.assertEquals(true, response.iterator().next().allowVNetOverride());
- Assertions.assertEquals("fvanpzabbf", response.iterator().next().status());
+ Assertions.assertEquals("ipqbyvesxuzda", response.iterator().next().policy().mode());
+ Assertions.assertEquals(FrequencyType.SECOND, response.iterator().next().policy().recurrence().frequency());
+ Assertions.assertEquals(891591548, response.iterator().next().policy().recurrence().interval());
+ Assertions.assertEquals(false, response.iterator().next().allowVNetOverride());
+ Assertions.assertEquals("wzjkbaudtpp", response.iterator().next().status());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStartWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStartWithResponseMockTests.java
index c3c550219e7a..410480f0ee50 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStartWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStartWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testStartWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.changeDataCaptures()
- .startWithResponse("ymaznmqlpn", "ppagv", "nryjqboylm", com.azure.core.util.Context.NONE);
+ .startWithResponse("q", "ymmqxndxppzyiyc", "powjyfbnqohc", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStatusWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStatusWithResponseMockTests.java
index 52007a06aea8..226b00eae616 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStatusWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStatusWithResponseMockTests.java
@@ -19,7 +19,7 @@
public final class ChangeDataCapturesStatusWithResponseMockTests {
@Test
public void testStatusWithResponse() throws Exception {
- String responseStr = "\"tq\"";
+ String responseStr = "\"ebyt\"";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -29,9 +29,9 @@ public void testStatusWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
String response = manager.changeDataCaptures()
- .statusWithResponse("rvnq", "dwsggjkzulihdh", "ccbbh", com.azure.core.util.Context.NONE)
+ .statusWithResponse("qijhvpvzfvegumsq", "acgfcbatfl", "pbgbzdhnmyyag", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("tq", response);
+ Assertions.assertEquals("ebyt", response);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStopWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStopWithResponseMockTests.java
index 8d7c4e6e282d..d2271a413edf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStopWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ChangeDataCapturesStopWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testStopWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.changeDataCaptures()
- .stopWithResponse("w", "zvmftxkwicg", "tbflechgiqxknjr", com.azure.core.util.Context.NONE);
+ .stopWithResponse("hmkpcrol", "xpalljveqx", "cbparyoa", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTests.java
index 832cfd469c3f..9a4c32813bf9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTests.java
@@ -19,35 +19,35 @@ public final class CommonDataServiceForAppsEntityDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CommonDataServiceForAppsEntityDataset model = BinaryData.fromString(
- "{\"type\":\"CommonDataServiceForAppsEntity\",\"typeProperties\":{\"entityName\":\"datazokn\"},\"description\":\"qddlggbq\",\"structure\":\"datalgzubak\",\"schema\":\"datakvggcmfns\",\"linkedServiceName\":{\"referenceName\":\"f\",\"parameters\":{\"gsmepnqvxgvoh\":\"datakmixwewzls\",\"pfhga\":\"databthhxmoevvude\",\"gayb\":\"datanvwxqhpjhubohxv\"}},\"parameters\":{\"v\":{\"type\":\"Float\",\"defaultValue\":\"datagalgxnwfm\"},\"fcssanybzzghvd\":{\"type\":\"String\",\"defaultValue\":\"datauebpamq\"}},\"annotations\":[\"datamyjsvcdhly\",\"datakh\"],\"folder\":{\"name\":\"junzxezriwg\"},\"\":{\"itibenwsdf\":\"dataapcqksaaapxjh\",\"ireszyaqg\":\"datavdaahlfrcqklpmvz\",\"cjjlwkyeahhhut\":\"datamlbmfggeokfe\",\"inowrerjpxp\":\"dataulnrfcqufmcih\"}}")
+ "{\"type\":\"CommonDataServiceForAppsEntity\",\"typeProperties\":{\"entityName\":\"datablwal\"},\"description\":\"ssnqe\",\"structure\":\"dataotbptg\",\"schema\":\"datamanxx\",\"linkedServiceName\":{\"referenceName\":\"wqfmdqecvta\",\"parameters\":{\"sibxovuqo\":\"datazmnobfeww\",\"qnzjcyqqz\":\"datajrkblndyclwgycv\",\"dpisjdl\":\"dataembtbwnalb\",\"eopsk\":\"dataajvmvvlooubsfxip\"}},\"parameters\":{\"dwzrgdqyxajc\":{\"type\":\"Bool\",\"defaultValue\":\"datamlupfazusjcdhusl\"},\"sjnkiixepbn\":{\"type\":\"Int\",\"defaultValue\":\"datacavqcwyzoqzkmqcw\"}},\"annotations\":[\"datawwgfgsqxilef\"],\"folder\":{\"name\":\"ewrznequqynttw\"},\"\":{\"ogjmqjhgcyd\":\"dataajksbs\",\"ixtdlxw\":\"datajnmcvjbssfcriqx\",\"orogeuv\":\"datavcdkucpxpyafrwr\",\"frsnqpljp\":\"datakrspnrsjsemlz\"}}")
.toObject(CommonDataServiceForAppsEntityDataset.class);
- Assertions.assertEquals("qddlggbq", model.description());
- Assertions.assertEquals("f", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("v").type());
- Assertions.assertEquals("junzxezriwg", model.folder().name());
+ Assertions.assertEquals("ssnqe", model.description());
+ Assertions.assertEquals("wqfmdqecvta", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("dwzrgdqyxajc").type());
+ Assertions.assertEquals("ewrznequqynttw", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CommonDataServiceForAppsEntityDataset model = new CommonDataServiceForAppsEntityDataset()
- .withDescription("qddlggbq")
- .withStructure("datalgzubak")
- .withSchema("datakvggcmfns")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("f")
- .withParameters(mapOf("gsmepnqvxgvoh", "datakmixwewzls", "pfhga", "databthhxmoevvude", "gayb",
- "datanvwxqhpjhubohxv")))
- .withParameters(
- mapOf("v", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datagalgxnwfm"),
- "fcssanybzzghvd",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datauebpamq")))
- .withAnnotations(Arrays.asList("datamyjsvcdhly", "datakh"))
- .withFolder(new DatasetFolder().withName("junzxezriwg"))
- .withEntityName("datazokn");
+ CommonDataServiceForAppsEntityDataset model
+ = new CommonDataServiceForAppsEntityDataset().withDescription("ssnqe")
+ .withStructure("dataotbptg")
+ .withSchema("datamanxx")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("wqfmdqecvta")
+ .withParameters(mapOf("sibxovuqo", "datazmnobfeww", "qnzjcyqqz", "datajrkblndyclwgycv", "dpisjdl",
+ "dataembtbwnalb", "eopsk", "dataajvmvvlooubsfxip")))
+ .withParameters(mapOf("dwzrgdqyxajc",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datamlupfazusjcdhusl"),
+ "sjnkiixepbn",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datacavqcwyzoqzkmqcw")))
+ .withAnnotations(Arrays.asList("datawwgfgsqxilef"))
+ .withFolder(new DatasetFolder().withName("ewrznequqynttw"))
+ .withEntityName("datablwal");
model = BinaryData.fromObject(model).toObject(CommonDataServiceForAppsEntityDataset.class);
- Assertions.assertEquals("qddlggbq", model.description());
- Assertions.assertEquals("f", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("v").type());
- Assertions.assertEquals("junzxezriwg", model.folder().name());
+ Assertions.assertEquals("ssnqe", model.description());
+ Assertions.assertEquals("wqfmdqecvta", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("dwzrgdqyxajc").type());
+ Assertions.assertEquals("ewrznequqynttw", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTypePropertiesTests.java
index c45bd1fc8ca3..720515e410a1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsEntityDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class CommonDataServiceForAppsEntityDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CommonDataServiceForAppsEntityDatasetTypeProperties model
- = BinaryData.fromString("{\"entityName\":\"datahdwyqqidqimlg\"}")
+ = BinaryData.fromString("{\"entityName\":\"dataexutike\"}")
.toObject(CommonDataServiceForAppsEntityDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
CommonDataServiceForAppsEntityDatasetTypeProperties model
- = new CommonDataServiceForAppsEntityDatasetTypeProperties().withEntityName("datahdwyqqidqimlg");
+ = new CommonDataServiceForAppsEntityDatasetTypeProperties().withEntityName("dataexutike");
model = BinaryData.fromObject(model).toObject(CommonDataServiceForAppsEntityDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsSourceTests.java
index 88c32036caca..c46cf75e2de6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CommonDataServiceForAppsSourceTests.java
@@ -11,18 +11,19 @@ public final class CommonDataServiceForAppsSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CommonDataServiceForAppsSource model = BinaryData.fromString(
- "{\"type\":\"CommonDataServiceForAppsSource\",\"query\":\"datajstncjwze\",\"additionalColumns\":\"dataezltlundkjphvh\",\"sourceRetryCount\":\"dataivsh\",\"sourceRetryWait\":\"datax\",\"maxConcurrentConnections\":\"datajythxearlpnajjt\",\"disableMetricsCollection\":\"datalyd\",\"\":{\"gucdfxglrcj\":\"dataxbungmpnry\",\"jcwuzanpoyrqjoni\":\"datagoazzy\",\"cloq\":\"datanyhzestt\",\"hfmzeufjzqaqeqc\":\"datagzdbonep\"}}")
+ "{\"type\":\"CommonDataServiceForAppsSource\",\"query\":\"dataljzrqw\",\"additionalColumns\":\"dataswemotjkejy\",\"sourceRetryCount\":\"datakyjvctqaqcz\",\"sourceRetryWait\":\"datapaeyklxsvcbr\",\"maxConcurrentConnections\":\"datalt\",\"disableMetricsCollection\":\"datamdsngoaofmrph\",\"\":{\"exibo\":\"datafrunkcgdnha\"}}")
.toObject(CommonDataServiceForAppsSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CommonDataServiceForAppsSource model = new CommonDataServiceForAppsSource().withSourceRetryCount("dataivsh")
- .withSourceRetryWait("datax")
- .withMaxConcurrentConnections("datajythxearlpnajjt")
- .withDisableMetricsCollection("datalyd")
- .withQuery("datajstncjwze")
- .withAdditionalColumns("dataezltlundkjphvh");
+ CommonDataServiceForAppsSource model
+ = new CommonDataServiceForAppsSource().withSourceRetryCount("datakyjvctqaqcz")
+ .withSourceRetryWait("datapaeyklxsvcbr")
+ .withMaxConcurrentConnections("datalt")
+ .withDisableMetricsCollection("datamdsngoaofmrph")
+ .withQuery("dataljzrqw")
+ .withAdditionalColumns("dataswemotjkejy");
model = BinaryData.fromObject(model).toObject(CommonDataServiceForAppsSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CompressionReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CompressionReadSettingsTests.java
index 5df7f22f4dc3..d982fd056d04 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CompressionReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CompressionReadSettingsTests.java
@@ -13,7 +13,7 @@ public final class CompressionReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CompressionReadSettings model = BinaryData.fromString(
- "{\"type\":\"CompressionReadSettings\",\"\":{\"qcjfqmyfgwb\":\"datagadkrknyyjngdf\",\"bq\":\"dataxqzfw\"}}")
+ "{\"type\":\"CompressionReadSettings\",\"\":{\"eqjnouuujli\":\"datastwaa\",\"hop\":\"dataicshmqxgjzs\",\"vkcnggoc\":\"dataqxipbxs\",\"lk\":\"datawnjmiitlamfb\"}}")
.toObject(CompressionReadSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurObjectDatasetTests.java
index b3709776f937..66f9eeb62134 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurObjectDatasetTests.java
@@ -19,38 +19,33 @@ public final class ConcurObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ConcurObjectDataset model = BinaryData.fromString(
- "{\"type\":\"ConcurObject\",\"typeProperties\":{\"tableName\":\"datadfvjsknrbxzepirt\"},\"description\":\"piqdqbvxqto\",\"structure\":\"datawbopvhcbtza\",\"schema\":\"datajxcontickfk\",\"linkedServiceName\":{\"referenceName\":\"thueocsgvuqzgbjw\",\"parameters\":{\"abes\":\"datadmpwewpmiolea\",\"ecmbaaj\":\"datayzwphbjks\",\"zkfekdesb\":\"datafwrdkql\",\"b\":\"datajqtl\"}},\"parameters\":{\"rr\":{\"type\":\"Array\",\"defaultValue\":\"datauibs\"},\"rcpzhbwcxybtdzyc\":{\"type\":\"String\",\"defaultValue\":\"dataeqrypyurvshhovtu\"},\"wczsrazcbybic\":{\"type\":\"Bool\",\"defaultValue\":\"dataoegjzgpljb\"},\"pua\":{\"type\":\"SecureString\",\"defaultValue\":\"datah\"}},\"annotations\":[\"datai\"],\"folder\":{\"name\":\"mu\"},\"\":{\"enndzgthdzit\":\"datawuycuo\",\"vswtwonadezm\":\"datazffpherwj\"}}")
+ "{\"type\":\"ConcurObject\",\"typeProperties\":{\"tableName\":\"dataf\"},\"description\":\"cnqbblr\",\"structure\":\"dataofzghfuifwxu\",\"schema\":\"datanoh\",\"linkedServiceName\":{\"referenceName\":\"cqxu\",\"parameters\":{\"fbplv\":\"dataugdcr\",\"qe\":\"datamhurosdjlzbdmddg\",\"orservpvesors\":\"datay\"}},\"parameters\":{\"fjqzyhzydyvtuq\":{\"type\":\"SecureString\",\"defaultValue\":\"datamex\"},\"igtvjxsocsvjekej\":{\"type\":\"SecureString\",\"defaultValue\":\"datalunssky\"}},\"annotations\":[\"datazjdcwuzscyf\",\"dataixecmasjnfgn\",\"dataxaojeeyvfxbfckmo\"],\"folder\":{\"name\":\"axvwxtxuzh\"},\"\":{\"ygtc\":\"datayffwflbkjcdzu\",\"jef\":\"dataz\",\"kbhzi\":\"dataubaldjcgldryvlr\"}}")
.toObject(ConcurObjectDataset.class);
- Assertions.assertEquals("piqdqbvxqto", model.description());
- Assertions.assertEquals("thueocsgvuqzgbjw", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("rr").type());
- Assertions.assertEquals("mu", model.folder().name());
+ Assertions.assertEquals("cnqbblr", model.description());
+ Assertions.assertEquals("cqxu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("fjqzyhzydyvtuq").type());
+ Assertions.assertEquals("axvwxtxuzh", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ConcurObjectDataset model = new ConcurObjectDataset().withDescription("piqdqbvxqto")
- .withStructure("datawbopvhcbtza")
- .withSchema("datajxcontickfk")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("thueocsgvuqzgbjw")
- .withParameters(mapOf("abes", "datadmpwewpmiolea", "ecmbaaj", "datayzwphbjks", "zkfekdesb",
- "datafwrdkql", "b", "datajqtl")))
- .withParameters(
- mapOf("rr", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datauibs"),
- "rcpzhbwcxybtdzyc",
- new ParameterSpecification().withType(ParameterType.STRING)
- .withDefaultValue("dataeqrypyurvshhovtu"),
- "wczsrazcbybic",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataoegjzgpljb"), "pua",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datah")))
- .withAnnotations(Arrays.asList("datai"))
- .withFolder(new DatasetFolder().withName("mu"))
- .withTableName("datadfvjsknrbxzepirt");
+ ConcurObjectDataset model = new ConcurObjectDataset().withDescription("cnqbblr")
+ .withStructure("dataofzghfuifwxu")
+ .withSchema("datanoh")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("cqxu")
+ .withParameters(mapOf("fbplv", "dataugdcr", "qe", "datamhurosdjlzbdmddg", "orservpvesors", "datay")))
+ .withParameters(mapOf("fjqzyhzydyvtuq",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datamex"),
+ "igtvjxsocsvjekej",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datalunssky")))
+ .withAnnotations(Arrays.asList("datazjdcwuzscyf", "dataixecmasjnfgn", "dataxaojeeyvfxbfckmo"))
+ .withFolder(new DatasetFolder().withName("axvwxtxuzh"))
+ .withTableName("dataf");
model = BinaryData.fromObject(model).toObject(ConcurObjectDataset.class);
- Assertions.assertEquals("piqdqbvxqto", model.description());
- Assertions.assertEquals("thueocsgvuqzgbjw", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("rr").type());
- Assertions.assertEquals("mu", model.folder().name());
+ Assertions.assertEquals("cnqbblr", model.description());
+ Assertions.assertEquals("cqxu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("fjqzyhzydyvtuq").type());
+ Assertions.assertEquals("axvwxtxuzh", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurSourceTests.java
index aa665c5d3094..38a156091902 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ConcurSourceTests.java
@@ -11,19 +11,19 @@ public final class ConcurSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ConcurSource model = BinaryData.fromString(
- "{\"type\":\"ConcurSource\",\"query\":\"datasmgh\",\"queryTimeout\":\"datatuujcuavctxyrmws\",\"additionalColumns\":\"datazmy\",\"sourceRetryCount\":\"datan\",\"sourceRetryWait\":\"dataajxv\",\"maxConcurrentConnections\":\"dataidlwmewrgu\",\"disableMetricsCollection\":\"dataugpkunvygupgnnvm\",\"\":{\"ekmsn\":\"dataqmxww\",\"jypxcqmdeecdh\":\"datafjbefszfrxfy\",\"mykgrtwh\":\"datajsizyhp\"}}")
+ "{\"type\":\"ConcurSource\",\"query\":\"dataanirlydsdmacydqa\",\"queryTimeout\":\"datayvwxubgulyz\",\"additionalColumns\":\"dataasxpprohuabdu\",\"sourceRetryCount\":\"datavsoxnpuapt\",\"sourceRetryWait\":\"datawekiqlscmtcljopi\",\"maxConcurrentConnections\":\"datawxvcfchokkcjjnq\",\"disableMetricsCollection\":\"datajoayaj\",\"\":{\"fbzbxeqzvokfrhfa\":\"datacxjmap\",\"uaxdulv\":\"dataxcgjuc\",\"mksgeqpai\":\"dataefsrxqscdbbwej\",\"eotvnet\":\"datalfscosf\"}}")
.toObject(ConcurSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ConcurSource model = new ConcurSource().withSourceRetryCount("datan")
- .withSourceRetryWait("dataajxv")
- .withMaxConcurrentConnections("dataidlwmewrgu")
- .withDisableMetricsCollection("dataugpkunvygupgnnvm")
- .withQueryTimeout("datatuujcuavctxyrmws")
- .withAdditionalColumns("datazmy")
- .withQuery("datasmgh");
+ ConcurSource model = new ConcurSource().withSourceRetryCount("datavsoxnpuapt")
+ .withSourceRetryWait("datawekiqlscmtcljopi")
+ .withMaxConcurrentConnections("datawxvcfchokkcjjnq")
+ .withDisableMetricsCollection("datajoayaj")
+ .withQueryTimeout("datayvwxubgulyz")
+ .withAdditionalColumns("dataasxpprohuabdu")
+ .withQuery("dataanirlydsdmacydqa");
model = BinaryData.fromObject(model).toObject(ConcurSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ControlActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ControlActivityTests.java
index b8c7a17afaaa..b8224e388e69 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ControlActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ControlActivityTests.java
@@ -20,49 +20,45 @@ public final class ControlActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ControlActivity model = BinaryData.fromString(
- "{\"type\":\"Container\",\"name\":\"dispasxwiicfsbj\",\"description\":\"adndowkxq\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ieehpvqfifrr\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Completed\"],\"\":{\"gqiismaggkt\":\"datayovc\",\"cxcmj\":\"dataoykrbk\"}},{\"activity\":\"ronxmtrhwwd\",\"dependencyConditions\":[\"Completed\"],\"\":{\"r\":\"datatyszhzlvkm\",\"ogtfp\":\"datavdbzarmepb\",\"ynkgnychuzhng\":\"dataskxsyohfrl\",\"oewfg\":\"datatbhjgliioeodgn\"}},{\"activity\":\"wmm\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Skipped\"],\"\":{\"jgkrppmvno\":\"datavexjqdjkonbgegw\"}},{\"activity\":\"t\",\"dependencyConditions\":[\"Failed\",\"Succeeded\",\"Skipped\"],\"\":{\"qspbdsco\":\"datahkdkv\",\"grjsqtirhabh\":\"dataidikxmtmjkfmrj\",\"jmbydrg\":\"datapcvsd\"}}],\"userProperties\":[{\"name\":\"mtjmux\",\"value\":\"datadmudw\"},{\"name\":\"uogmth\",\"value\":\"dataqcyycxlllk\"}],\"\":{\"sgiebqvuscmcegyi\":\"datajlwf\"}}")
+ "{\"type\":\"Container\",\"name\":\"exkoncia\",\"description\":\"l\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"xkctedh\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Failed\"],\"\":{\"bu\":\"dataajniwbyzyjuyxyl\",\"sigkinykjxq\":\"dataojdzcluy\",\"jqpjzturdi\":\"dataspeqgedpi\",\"oqakvutedetxokqu\":\"dataerkwmafy\"}},{\"activity\":\"jdwcwj\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\"],\"\":{\"blfefbbvitlnnp\":\"dataehxahnqjbav\"}},{\"activity\":\"fufwrerbndr\",\"dependencyConditions\":[\"Failed\",\"Succeeded\",\"Completed\"],\"\":{\"py\":\"dataavmdcctemvaajyi\",\"swurzaqubryhvbv\":\"datagwih\"}}],\"userProperties\":[{\"name\":\"dwaupjo\",\"value\":\"datagryocgwkp\"},{\"name\":\"ilyznbb\",\"value\":\"dataimxznfoaks\"}],\"\":{\"iwf\":\"dataswznlbbhtl\"}}")
.toObject(ControlActivity.class);
- Assertions.assertEquals("dispasxwiicfsbj", model.name());
- Assertions.assertEquals("adndowkxq", model.description());
+ Assertions.assertEquals("exkoncia", model.name());
+ Assertions.assertEquals("l", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ieehpvqfifrr", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("xkctedh", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("mtjmux", model.userProperties().get(0).name());
+ Assertions.assertEquals("dwaupjo", model.userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ControlActivity model = new ControlActivity().withName("dispasxwiicfsbj")
- .withDescription("adndowkxq")
+ ControlActivity model = new ControlActivity().withName("exkoncia")
+ .withDescription("l")
.withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ieehpvqfifrr")
+ new ActivityDependency().withActivity("xkctedh")
.withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ DependencyCondition.COMPLETED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ronxmtrhwwd")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("jdwcwj")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wmm")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED,
- DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("t")
+ new ActivityDependency().withActivity("fufwrerbndr")
.withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SUCCEEDED,
- DependencyCondition.SKIPPED))
+ DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("mtjmux").withValue("datadmudw"),
- new UserProperty().withName("uogmth").withValue("dataqcyycxlllk")));
+ .withUserProperties(Arrays.asList(new UserProperty().withName("dwaupjo").withValue("datagryocgwkp"),
+ new UserProperty().withName("ilyznbb").withValue("dataimxznfoaks")));
model = BinaryData.fromObject(model).toObject(ControlActivity.class);
- Assertions.assertEquals("dispasxwiicfsbj", model.name());
- Assertions.assertEquals("adndowkxq", model.description());
+ Assertions.assertEquals("exkoncia", model.name());
+ Assertions.assertEquals("l", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ieehpvqfifrr", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("xkctedh", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("mtjmux", model.userProperties().get(0).name());
+ Assertions.assertEquals("dwaupjo", model.userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityLogSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityLogSettingsTests.java
index 34bbb6f94c8a..5212d8bad6ce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityLogSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityLogSettingsTests.java
@@ -11,14 +11,14 @@ public final class CopyActivityLogSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CopyActivityLogSettings model
- = BinaryData.fromString("{\"logLevel\":\"dataynupski\",\"enableReliableLogging\":\"datakphamefzzgwjoau\"}")
+ = BinaryData.fromString("{\"logLevel\":\"datavsf\",\"enableReliableLogging\":\"datacarfdmlie\"}")
.toObject(CopyActivityLogSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CopyActivityLogSettings model = new CopyActivityLogSettings().withLogLevel("dataynupski")
- .withEnableReliableLogging("datakphamefzzgwjoau");
+ CopyActivityLogSettings model
+ = new CopyActivityLogSettings().withLogLevel("datavsf").withEnableReliableLogging("datacarfdmlie");
model = BinaryData.fromObject(model).toObject(CopyActivityLogSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTests.java
index 3bd058dcccdd..21318d8e02d8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTests.java
@@ -32,132 +32,125 @@ public final class CopyActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CopyActivity model = BinaryData.fromString(
- "{\"type\":\"Copy\",\"typeProperties\":{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"datamkmwdok\",\"sourceRetryWait\":\"datayilho\",\"maxConcurrentConnections\":\"datatdioxgsrhxoyrgv\",\"disableMetricsCollection\":\"datacctm\",\"\":{\"rarukdepsxu\":\"databplqh\"}},\"sink\":{\"type\":\"CopySink\",\"writeBatchSize\":\"dataqcqfouh\",\"writeBatchTimeout\":\"datayxgxbgochpx\",\"sinkRetryCount\":\"datawpwwsioozrugbdk\",\"sinkRetryWait\":\"datawckuvlzkzjjta\",\"maxConcurrentConnections\":\"dataqjebtdpsg\",\"disableMetricsCollection\":\"datae\",\"\":{\"tytwtfqpmpyww\":\"datazpkvyl\",\"mjc\":\"databuk\",\"nc\":\"datadoecdq\"}},\"translator\":\"datacocchdxjrrb\",\"enableStaging\":\"databnkqps\",\"stagingSettings\":{\"linkedServiceName\":{\"referenceName\":\"ouppzgdtuhd\",\"parameters\":{\"rzhzf\":\"dataojcmhycdxwv\",\"fyltornvbhuy\":\"datac\",\"vcy\":\"datalwifbdwy\",\"zvejqzyu\":\"databbvkthre\"}},\"path\":\"datalokeqe\",\"enableCompression\":\"databpiie\",\"\":{\"v\":\"datachsgotgwerbpo\",\"nicgrxcei\":\"datah\",\"dtkllqhznutrx\":\"datav\",\"jh\":\"datamztrnniarje\"}},\"parallelCopies\":\"dataiqfoqw\",\"dataIntegrationUnits\":\"dataqykqfserlsaip\",\"enableSkipIncompatibleRow\":\"datahetagwmzg\",\"redirectIncompatibleRowSettings\":{\"linkedServiceName\":\"dataojgmobkaligo\",\"path\":\"datakehpdssvlubdp\",\"\":{\"mixu\":\"dataxsxbxd\",\"hmtbu\":\"datacekcqmjqqauft\",\"irshl\":\"datakcnkghkr\",\"xyofftxzovbhqel\":\"dataeayodrvwnqb\"}},\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"lfxejpo\",\"parameters\":{\"lgstrzfhehd\":\"dataigsabtxndyjwm\",\"ohnymfhmlji\":\"dataovkbcbe\"}},\"path\":\"datagfvzvmtjcxig\",\"logLevel\":\"datazxdb\",\"enableReliableLogging\":\"dataceetuivmbu\",\"\":{\"pjulsl\":\"datawywfhfptbdxtv\"}},\"logSettings\":{\"enableCopyActivityLog\":\"datazytxe\",\"copyActivityLogSettings\":{\"logLevel\":\"datagmqntutetdt\",\"enableReliableLogging\":\"dataidbrjw\"},\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"wouepaqn\",\"parameters\":{\"ecttub\":\"datagrcmcqppledx\",\"hwpxps\":\"datawelutrvd\",\"ccya\":\"datawyltsl\"}},\"path\":\"datasfmndrdqqjkegbm\"}},\"preserveRules\":[\"dataciherzkhiovhjk\"],\"preserve\":[\"datalpjrepahvoir\",\"datanxqn\"],\"validateDataConsistency\":\"datasvnldtqykzmwd\",\"skipErrorFile\":{\"fileMissing\":\"dataejltrnqxicyo\",\"dataInconsistency\":\"datayo\"}},\"inputs\":[{\"referenceName\":\"rxfxycjia\",\"parameters\":{\"gm\":\"datahfuml\",\"qlrt\":\"datazxxkokipklfwnhfk\",\"jitbnhglrvlarozs\":\"datafswqdkv\"}},{\"referenceName\":\"mucr\",\"parameters\":{\"nlvjgskbksltun\":\"datagsdxtwqqukg\",\"uqyzxzjehd\":\"datawxsqvxlupccfwqis\",\"pgmoazsj\":\"datalvqtmzociaetctj\",\"ccvxqbxgq\":\"datauevfvnnt\"}}],\"outputs\":[{\"referenceName\":\"nri\",\"parameters\":{\"ldi\":\"datakibvw\"}},{\"referenceName\":\"mxsvz\",\"parameters\":{\"dljthmibqgldhtt\":\"datatalobx\",\"nny\":\"dataalpq\"}}],\"linkedServiceName\":{\"referenceName\":\"jea\",\"parameters\":{\"fdkkvijilfqvodz\":\"dataewlwbxuf\",\"ld\":\"datawdqvq\",\"qpfwnjdyoxformfe\":\"dataqoaop\"}},\"policy\":{\"timeout\":\"dataqjneszxte\",\"retry\":\"datahxphxokdbv\",\"retryIntervalInSeconds\":187311,\"secureInput\":false,\"secureOutput\":true,\"\":{\"jrnnwgrxzcn\":\"dataxbzmpvue\",\"zqlsnycchpcjzt\":\"dataguezxluimkwbwmg\",\"njxciunetcxgdg\":\"dataiuuuyvpcfv\",\"tzbphxxvftj\":\"datakletlwa\"}},\"name\":\"rq\",\"description\":\"onmokyjmtdny\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"bqlcakle\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Skipped\"],\"\":{\"xgg\":\"dataezyhphaokhbq\",\"oclef\":\"datakqitpbynetyxuxo\"}},{\"activity\":\"gg\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"rvswcpspaoxigp\":\"databouhmngccnkgiu\",\"u\":\"datai\"}},{\"activity\":\"pgpqsmglutn\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"idbcxbgfwwcfwl\":\"dataxxnbogx\",\"imviefbje\":\"datanjganmopcmetdruu\",\"khjuuepnjuqw\":\"datamiy\"}}],\"userProperties\":[{\"name\":\"bbpxqsv\",\"value\":\"dataxvqwisdwtug\"}],\"\":{\"cbwiwhtjox\":\"dataupip\"}}")
+ "{\"type\":\"Copy\",\"typeProperties\":{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"datafhfptbdxtvlpj\",\"sourceRetryWait\":\"datasl\",\"maxConcurrentConnections\":\"datauzytxeaqig\",\"disableMetricsCollection\":\"datantutetdtgci\",\"\":{\"qnfyhgrcmcqpp\":\"datajwiwouep\",\"xyecttu\":\"datae\"}},\"sink\":{\"type\":\"CopySink\",\"writeBatchSize\":\"datawelutrvd\",\"writeBatchTimeout\":\"datawp\",\"sinkRetryCount\":\"datascwyltslf\",\"sinkRetryWait\":\"datayavysfmndrdqq\",\"maxConcurrentConnections\":\"dataeg\",\"disableMetricsCollection\":\"dataldkciherzkh\",\"\":{\"oiranxq\":\"datahjkwfolpjrepah\",\"nldt\":\"datazss\",\"qxi\":\"dataykzmwdoqrejltr\"}},\"translator\":\"dataozryoxmfrxfxyc\",\"enableStaging\":\"dataalvchfumlf\",\"stagingSettings\":{\"linkedServiceName\":{\"referenceName\":\"lzxxkokipklfwnhf\",\"parameters\":{\"hg\":\"datalrtffswqdkvljitb\"}},\"path\":\"datavlaro\",\"enableCompression\":\"datawmucrzabgsdxtw\",\"\":{\"kbksltunrwxsq\":\"datakgonlvjg\"}},\"parallelCopies\":\"datalupccfwqisouqy\",\"dataIntegrationUnits\":\"datazjehdklvqtmzoci\",\"enableSkipIncompatibleRow\":\"datatctjhpgmoazsjsu\",\"redirectIncompatibleRowSettings\":{\"linkedServiceName\":\"datafvnntrccvxqb\",\"path\":\"dataq\",\"\":{\"xekibv\":\"datanri\",\"bxldl\":\"dataqldilmxsvzwbktal\"}},\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"hmibqgldhtt\",\"parameters\":{\"alxlewlwbxufqf\":\"datapqlnnyevj\",\"lfqvo\":\"datakkvij\"}},\"path\":\"dataowdqvqfldaqoao\",\"logLevel\":\"dataqpfwnjdyoxformfe\",\"enableReliableLogging\":\"datafq\",\"\":{\"hxphxokdbv\":\"dataszxtes\",\"bz\":\"datapqttusux\",\"jrnnwgrxzcn\":\"datapvue\"}},\"logSettings\":{\"enableCopyActivityLog\":\"dataezxluimkwb\",\"copyActivityLogSettings\":{\"logLevel\":\"dataq\",\"enableReliableLogging\":\"datal\"},\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"nycchpcjztz\",\"parameters\":{\"vp\":\"datau\",\"xciunet\":\"datafvin\",\"hxxvft\":\"dataxgdgqkletlwavtzb\",\"kyjmtdnymbe\":\"datadrqgionm\"}},\"path\":\"dataskb\"}},\"preserveRules\":[\"dataaklesjgxdhgezy\",\"dataphaokhbqmxgglk\"],\"preserve\":[\"datapbynetyxuxopoc\"],\"validateDataConsistency\":\"dataffgggglz\",\"skipErrorFile\":{\"fileMissing\":\"datauhmngc\",\"dataInconsistency\":\"datakgiusrvs\"}},\"inputs\":[{\"referenceName\":\"spaoxi\",\"parameters\":{\"u\":\"datai\",\"yn\":\"datapgpqsmglutn\",\"xbgfwwcfwlwnj\":\"datalxxnbogxkidb\"}},{\"referenceName\":\"anm\",\"parameters\":{\"fbjesmiyj\":\"datametdruugimvi\",\"xqsvax\":\"datahjuuepnjuqwnajbb\"}}],\"outputs\":[{\"referenceName\":\"isdwtug\",\"parameters\":{\"cbwiwhtjox\":\"dataupip\"}},{\"referenceName\":\"llhkzunnwmwwxy\",\"parameters\":{\"qmcvu\":\"datakdvevhyuuihap\",\"fiiif\":\"dataekubljnizwztlcr\",\"ervtrulzlrmrt\":\"dataxnfarmficqr\"}},{\"referenceName\":\"smpmhlcxb\",\"parameters\":{\"bicjzntiblxeygo\":\"datagcdfelvapb\",\"oanpkcmdixiu\":\"datauhroicjtgqdy\",\"zlvhohzkcsjddzpo\":\"dataqbcalgspzoafp\"}},{\"referenceName\":\"mnmkypeqmuue\",\"parameters\":{\"y\":\"datakrulavxe\",\"chwpfunptsry\":\"dataf\"}}],\"linkedServiceName\":{\"referenceName\":\"a\",\"parameters\":{\"baddlmj\":\"datawbxvsytbxcj\",\"rc\":\"dataulio\",\"valezkyfykm\":\"datanthluze\"}},\"policy\":{\"timeout\":\"dataasuwep\",\"retry\":\"datagtyt\",\"retryIntervalInSeconds\":333163893,\"secureInput\":false,\"secureOutput\":true,\"\":{\"ykshizwdswikyewv\":\"datafqffwvnjgj\",\"meftlgjrfkqf\":\"datakzwqzwsguipqq\",\"kxk\":\"datadrel\"}},\"name\":\"glua\",\"description\":\"gjoy\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"vrmenrcqickhvps\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Completed\"],\"\":{\"yojzvaykfjgakays\":\"datangmonqyntyuqdz\",\"zwm\":\"datakydqy\",\"muot\":\"datawrqzizgg\"}}],\"userProperties\":[{\"name\":\"abfyjampvwx\",\"value\":\"datakhprlt\"},{\"name\":\"ipmnqrbyq\",\"value\":\"datayw\"}],\"\":{\"yu\":\"datawcjkargg\"}}")
.toObject(CopyActivity.class);
- Assertions.assertEquals("rq", model.name());
- Assertions.assertEquals("onmokyjmtdny", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("bqlcakle", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("bbpxqsv", model.userProperties().get(0).name());
- Assertions.assertEquals("jea", model.linkedServiceName().referenceName());
- Assertions.assertEquals(187311, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("glua", model.name());
+ Assertions.assertEquals("gjoy", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("vrmenrcqickhvps", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("abfyjampvwx", model.userProperties().get(0).name());
+ Assertions.assertEquals("a", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(333163893, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
- Assertions.assertEquals("rxfxycjia", model.inputs().get(0).referenceName());
- Assertions.assertEquals("nri", model.outputs().get(0).referenceName());
- Assertions.assertEquals("ouppzgdtuhd", model.stagingSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("lfxejpo", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("wouepaqn",
+ Assertions.assertEquals("spaoxi", model.inputs().get(0).referenceName());
+ Assertions.assertEquals("isdwtug", model.outputs().get(0).referenceName());
+ Assertions.assertEquals("lzxxkokipklfwnhf", model.stagingSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("hmibqgldhtt", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("nycchpcjztz",
model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CopyActivity model = new CopyActivity().withName("rq")
- .withDescription("onmokyjmtdny")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("bqlcakle")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("gg")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("pgpqsmglutn")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("bbpxqsv").withValue("dataxvqwisdwtug")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("jea")
- .withParameters(
- mapOf("fdkkvijilfqvodz", "dataewlwbxuf", "ld", "datawdqvq", "qpfwnjdyoxformfe", "dataqoaop")))
- .withPolicy(new ActivityPolicy().withTimeout("dataqjneszxte")
- .withRetry("datahxphxokdbv")
- .withRetryIntervalInSeconds(187311)
+ CopyActivity model = new CopyActivity().withName("glua")
+ .withDescription("gjoy")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("vrmenrcqickhvps")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED,
+ DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("abfyjampvwx").withValue("datakhprlt"),
+ new UserProperty().withName("ipmnqrbyq").withValue("datayw")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("a")
+ .withParameters(mapOf("baddlmj", "datawbxvsytbxcj", "rc", "dataulio", "valezkyfykm", "datanthluze")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataasuwep")
+ .withRetry("datagtyt")
+ .withRetryIntervalInSeconds(333163893)
.withSecureInput(false)
.withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withInputs(
- Arrays.asList(
- new DatasetReference().withReferenceName("rxfxycjia")
- .withParameters(mapOf("gm", "datahfuml", "qlrt", "datazxxkokipklfwnhfk", "jitbnhglrvlarozs",
- "datafswqdkv")),
- new DatasetReference().withReferenceName("mucr")
- .withParameters(mapOf("nlvjgskbksltun", "datagsdxtwqqukg", "uqyzxzjehd", "datawxsqvxlupccfwqis",
- "pgmoazsj", "datalvqtmzociaetctj", "ccvxqbxgq", "datauevfvnnt"))))
- .withOutputs(
- Arrays.asList(new DatasetReference().withReferenceName("nri").withParameters(mapOf("ldi", "datakibvw")),
- new DatasetReference().withReferenceName("mxsvz")
- .withParameters(mapOf("dljthmibqgldhtt", "datatalobx", "nny", "dataalpq"))))
- .withSource(new CopySource().withSourceRetryCount("datamkmwdok")
- .withSourceRetryWait("datayilho")
- .withMaxConcurrentConnections("datatdioxgsrhxoyrgv")
- .withDisableMetricsCollection("datacctm")
+ .withInputs(Arrays.asList(
+ new DatasetReference().withReferenceName("spaoxi")
+ .withParameters(mapOf("u", "datai", "yn", "datapgpqsmglutn", "xbgfwwcfwlwnj", "datalxxnbogxkidb")),
+ new DatasetReference().withReferenceName("anm")
+ .withParameters(mapOf("fbjesmiyj", "datametdruugimvi", "xqsvax", "datahjuuepnjuqwnajbb"))))
+ .withOutputs(Arrays.asList(
+ new DatasetReference().withReferenceName("isdwtug").withParameters(mapOf("cbwiwhtjox", "dataupip")),
+ new DatasetReference().withReferenceName("llhkzunnwmwwxy")
+ .withParameters(mapOf("qmcvu", "datakdvevhyuuihap", "fiiif", "dataekubljnizwztlcr", "ervtrulzlrmrt",
+ "dataxnfarmficqr")),
+ new DatasetReference().withReferenceName("smpmhlcxb")
+ .withParameters(mapOf("bicjzntiblxeygo", "datagcdfelvapb", "oanpkcmdixiu", "datauhroicjtgqdy",
+ "zlvhohzkcsjddzpo", "dataqbcalgspzoafp")),
+ new DatasetReference().withReferenceName("mnmkypeqmuue")
+ .withParameters(mapOf("y", "datakrulavxe", "chwpfunptsry", "dataf"))))
+ .withSource(new CopySource().withSourceRetryCount("datafhfptbdxtvlpj")
+ .withSourceRetryWait("datasl")
+ .withMaxConcurrentConnections("datauzytxeaqig")
+ .withDisableMetricsCollection("datantutetdtgci")
.withAdditionalProperties(mapOf("type", "CopySource")))
- .withSink(new CopySink().withWriteBatchSize("dataqcqfouh")
- .withWriteBatchTimeout("datayxgxbgochpx")
- .withSinkRetryCount("datawpwwsioozrugbdk")
- .withSinkRetryWait("datawckuvlzkzjjta")
- .withMaxConcurrentConnections("dataqjebtdpsg")
- .withDisableMetricsCollection("datae")
+ .withSink(new CopySink().withWriteBatchSize("datawelutrvd")
+ .withWriteBatchTimeout("datawp")
+ .withSinkRetryCount("datascwyltslf")
+ .withSinkRetryWait("datayavysfmndrdqq")
+ .withMaxConcurrentConnections("dataeg")
+ .withDisableMetricsCollection("dataldkciherzkh")
.withAdditionalProperties(mapOf("type", "CopySink")))
- .withTranslator("datacocchdxjrrb")
- .withEnableStaging("databnkqps")
+ .withTranslator("dataozryoxmfrxfxyc")
+ .withEnableStaging("dataalvchfumlf")
.withStagingSettings(new StagingSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ouppzgdtuhd")
- .withParameters(mapOf("rzhzf", "dataojcmhycdxwv", "fyltornvbhuy", "datac", "vcy", "datalwifbdwy",
- "zvejqzyu", "databbvkthre")))
- .withPath("datalokeqe")
- .withEnableCompression("databpiie")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lzxxkokipklfwnhf")
+ .withParameters(mapOf("hg", "datalrtffswqdkvljitb")))
+ .withPath("datavlaro")
+ .withEnableCompression("datawmucrzabgsdxtw")
.withAdditionalProperties(mapOf()))
- .withParallelCopies("dataiqfoqw")
- .withDataIntegrationUnits("dataqykqfserlsaip")
- .withEnableSkipIncompatibleRow("datahetagwmzg")
+ .withParallelCopies("datalupccfwqisouqy")
+ .withDataIntegrationUnits("datazjehdklvqtmzoci")
+ .withEnableSkipIncompatibleRow("datatctjhpgmoazsjsu")
.withRedirectIncompatibleRowSettings(
- new RedirectIncompatibleRowSettings().withLinkedServiceName("dataojgmobkaligo")
- .withPath("datakehpdssvlubdp")
+ new RedirectIncompatibleRowSettings().withLinkedServiceName("datafvnntrccvxqb")
+ .withPath("dataq")
.withAdditionalProperties(mapOf()))
.withLogStorageSettings(new LogStorageSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lfxejpo")
- .withParameters(mapOf("lgstrzfhehd", "dataigsabtxndyjwm", "ohnymfhmlji", "dataovkbcbe")))
- .withPath("datagfvzvmtjcxig")
- .withLogLevel("datazxdb")
- .withEnableReliableLogging("dataceetuivmbu")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hmibqgldhtt")
+ .withParameters(mapOf("alxlewlwbxufqf", "datapqlnnyevj", "lfqvo", "datakkvij")))
+ .withPath("dataowdqvqfldaqoao")
+ .withLogLevel("dataqpfwnjdyoxformfe")
+ .withEnableReliableLogging("datafq")
.withAdditionalProperties(mapOf()))
- .withLogSettings(new LogSettings().withEnableCopyActivityLog("datazytxe")
- .withCopyActivityLogSettings(new CopyActivityLogSettings().withLogLevel("datagmqntutetdt")
- .withEnableReliableLogging("dataidbrjw"))
- .withLogLocationSettings(
- new LogLocationSettings()
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("wouepaqn")
- .withParameters(mapOf("ecttub", "datagrcmcqppledx", "hwpxps", "datawelutrvd", "ccya",
- "datawyltsl")))
- .withPath("datasfmndrdqqjkegbm")))
- .withPreserveRules(Arrays.asList("dataciherzkhiovhjk"))
- .withPreserve(Arrays.asList("datalpjrepahvoir", "datanxqn"))
- .withValidateDataConsistency("datasvnldtqykzmwd")
- .withSkipErrorFile(new SkipErrorFile().withFileMissing("dataejltrnqxicyo").withDataInconsistency("datayo"));
+ .withLogSettings(new LogSettings().withEnableCopyActivityLog("dataezxluimkwb")
+ .withCopyActivityLogSettings(
+ new CopyActivityLogSettings().withLogLevel("dataq").withEnableReliableLogging("datal"))
+ .withLogLocationSettings(new LogLocationSettings()
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("nycchpcjztz")
+ .withParameters(mapOf("vp", "datau", "xciunet", "datafvin", "hxxvft", "dataxgdgqkletlwavtzb",
+ "kyjmtdnymbe", "datadrqgionm")))
+ .withPath("dataskb")))
+ .withPreserveRules(Arrays.asList("dataaklesjgxdhgezy", "dataphaokhbqmxgglk"))
+ .withPreserve(Arrays.asList("datapbynetyxuxopoc"))
+ .withValidateDataConsistency("dataffgggglz")
+ .withSkipErrorFile(new SkipErrorFile().withFileMissing("datauhmngc").withDataInconsistency("datakgiusrvs"));
model = BinaryData.fromObject(model).toObject(CopyActivity.class);
- Assertions.assertEquals("rq", model.name());
- Assertions.assertEquals("onmokyjmtdny", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("bqlcakle", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("bbpxqsv", model.userProperties().get(0).name());
- Assertions.assertEquals("jea", model.linkedServiceName().referenceName());
- Assertions.assertEquals(187311, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("glua", model.name());
+ Assertions.assertEquals("gjoy", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("vrmenrcqickhvps", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("abfyjampvwx", model.userProperties().get(0).name());
+ Assertions.assertEquals("a", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(333163893, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
- Assertions.assertEquals("rxfxycjia", model.inputs().get(0).referenceName());
- Assertions.assertEquals("nri", model.outputs().get(0).referenceName());
- Assertions.assertEquals("ouppzgdtuhd", model.stagingSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("lfxejpo", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("wouepaqn",
+ Assertions.assertEquals("spaoxi", model.inputs().get(0).referenceName());
+ Assertions.assertEquals("isdwtug", model.outputs().get(0).referenceName());
+ Assertions.assertEquals("lzxxkokipklfwnhf", model.stagingSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("hmibqgldhtt", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("nycchpcjztz",
model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTypePropertiesTests.java
index c273167c6a52..d0035e9f5207 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyActivityTypePropertiesTests.java
@@ -25,68 +25,71 @@ public final class CopyActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CopyActivityTypeProperties model = BinaryData.fromString(
- "{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"datalhkz\",\"sourceRetryWait\":\"datanw\",\"maxConcurrentConnections\":\"datawxyawxkdvev\",\"disableMetricsCollection\":\"datauuihapcqmcvur\",\"\":{\"tlcrxfiiifgxnfar\":\"databljnizw\",\"vtrulzlrm\":\"dataficqrde\",\"xcgcdfel\":\"datatcsmpmhlcxb\",\"ygosuhroicjt\":\"dataapbdbicjzntiblx\"}},\"sink\":{\"type\":\"CopySink\",\"writeBatchSize\":\"datadymoanpkcmdixiux\",\"writeBatchTimeout\":\"datacalgspz\",\"sinkRetryCount\":\"datafprzlvhohzkcsjd\",\"sinkRetryWait\":\"dataposmnmkypeqm\",\"maxConcurrentConnections\":\"dataeox\",\"disableMetricsCollection\":\"datarulavxeaym\",\"\":{\"funptsryp\":\"datahw\",\"kbwbxvs\":\"dataa\",\"baddlmj\":\"datatbxcj\"}},\"translator\":\"datali\",\"enableStaging\":\"datarc\",\"stagingSettings\":{\"linkedServiceName\":{\"referenceName\":\"thluzey\",\"parameters\":{\"mn\":\"dataezkyfy\",\"pqegty\":\"dataeasuw\",\"tfqffwvnjg\":\"databycceuf\",\"sw\":\"datarykshizw\"}},\"path\":\"dataye\",\"enableCompression\":\"datas\",\"\":{\"qqemeftlgjrf\":\"dataqzwsgui\",\"relokxklgluareg\":\"dataqfc\"}},\"parallelCopies\":\"datay\",\"dataIntegrationUnits\":\"dataoisbmv\",\"enableSkipIncompatibleRow\":\"dataenrcqickhvps\",\"redirectIncompatibleRowSettings\":{\"linkedServiceName\":\"datauiuvingmonq\",\"path\":\"datatyuqdz\",\"\":{\"kydqy\":\"datajzvaykfjgakays\"}},\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"wmfwr\",\"parameters\":{\"vmuot\":\"datazg\",\"fyjampvwxlkh\":\"datasea\",\"ipmnqrbyq\":\"datarlt\"}},\"path\":\"datawxbowcjkargg\",\"logLevel\":\"datauewgy\",\"enableReliableLogging\":\"datalvxwlqlugnbudjy\",\"\":{\"ykvlxs\":\"dataotgtlan\",\"xooxuaufqoo\":\"datacqqd\",\"t\":\"datawx\"}},\"logSettings\":{\"enableCopyActivityLog\":\"dataqvpedwmhqcjreryp\",\"copyActivityLogSettings\":{\"logLevel\":\"dataqxeyzqnupsipclxv\",\"enableReliableLogging\":\"datavss\"},\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"b\",\"parameters\":{\"icqdb\":\"dataq\",\"lrixzdbntopbab\":\"datazwlejiiyoonbu\",\"boysquygokh\":\"datadwcfmzmqmgdlgsxk\",\"qukcojyxhhvoo\":\"datastwcyigrhfevxy\"}},\"path\":\"datatcsucot\"}},\"preserveRules\":[\"dataiqzjnxzvjnmpv\"],\"preserve\":[\"dataudfbhzuk\",\"datapfbhihddiiuex\"],\"validateDataConsistency\":\"datayfku\",\"skipErrorFile\":{\"fileMissing\":\"dataqpwardpw\",\"dataInconsistency\":\"datalvfisk\"}}")
+ "{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"datagylo\",\"sourceRetryWait\":\"dataxwlql\",\"maxConcurrentConnections\":\"datanbudjypliotg\",\"disableMetricsCollection\":\"dataansykvlxsycq\",\"\":{\"wx\":\"dataxooxuaufqoo\",\"veqvpedwmhqcjr\":\"datat\",\"zqnupsipclxvaov\":\"datarypjbyqxe\",\"vqqvicqdbmzwlej\":\"datasib\"}},\"sink\":{\"type\":\"CopySink\",\"writeBatchSize\":\"datayoonbualri\",\"writeBatchTimeout\":\"datadbnt\",\"sinkRetryCount\":\"datababndwcfmz\",\"sinkRetryWait\":\"datamgdlgsxkyboysquy\",\"maxConcurrentConnections\":\"datakh\",\"disableMetricsCollection\":\"datatwcyigrhfevxypqu\",\"\":{\"xhhvoo\":\"dataj\",\"wyiq\":\"datartcsucot\",\"bhzukrpfbhihddi\":\"datajnxzvjnmpvsblud\",\"yfku\":\"datauexy\"}},\"translator\":\"datalq\",\"enableStaging\":\"dataa\",\"stagingSettings\":{\"linkedServiceName\":{\"referenceName\":\"pwrmlv\",\"parameters\":{\"xnyock\":\"datakkqspzw\"}},\"path\":\"datassusdrgzmmrzwm\",\"enableCompression\":\"datatkcvolaxnuk\",\"\":{\"oxyxiyhmjwsn\":\"dataoumndc\"}},\"parallelCopies\":\"dataezgvaeqiygbou\",\"dataIntegrationUnits\":\"datajodidgudar\",\"enableSkipIncompatibleRow\":\"dataajbenf\",\"redirectIncompatibleRowSettings\":{\"linkedServiceName\":\"dataufvojikffczw\",\"path\":\"datawpilsuhsghdovcpb\",\"\":{\"hsixzcdaukh\":\"dataapgag\"}},\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"h\",\"parameters\":{\"ojker\":\"databomf\",\"togbkdctsg\":\"dataujfnbzamroad\",\"cnecl\":\"dataalh\",\"nsl\":\"datahmjsqcubyj\"}},\"path\":\"datateena\",\"logLevel\":\"dataecsft\",\"enableReliableLogging\":\"dataubzfuhj\",\"\":{\"qgvt\":\"datacyrbzyj\",\"vdvkeyqxjchdnlx\":\"datadxtwyxpkwwdkkvd\",\"xqpsqpfxjwt\":\"datailuexvml\",\"xrjjdjikiqtzub\":\"datalbqkguchd\"}},\"logSettings\":{\"enableCopyActivityLog\":\"datakujv\",\"copyActivityLogSettings\":{\"logLevel\":\"datauq\",\"enableReliableLogging\":\"datalwnxryyqtjcrpax\"},\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"xlfxsetvdz\",\"parameters\":{\"zhdciuxotb\":\"datadmxfqftywbba\",\"hop\":\"dataflgkkiu\",\"rtaevq\":\"datafobpyeo\",\"owsmrvdtqhr\":\"datafdhpkiiunyrobcke\"}},\"path\":\"dataqs\"}},\"preserveRules\":[\"datanupskit\",\"datakphamefzzgwjoau\"],\"preserve\":[\"datadpn\",\"dataouylfcfgqinaokx\",\"datauknzhmza\"],\"validateDataConsistency\":\"datarsqzuknbtxtdm\",\"skipErrorFile\":{\"fileMissing\":\"datarrqqajhklttl\",\"dataInconsistency\":\"datawdrt\"}}")
.toObject(CopyActivityTypeProperties.class);
- Assertions.assertEquals("thluzey", model.stagingSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("wmfwr", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("b", model.logSettings().logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("pwrmlv", model.stagingSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("h", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("xlfxsetvdz",
+ model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
CopyActivityTypeProperties model = new CopyActivityTypeProperties()
- .withSource(new CopySource().withSourceRetryCount("datalhkz")
- .withSourceRetryWait("datanw")
- .withMaxConcurrentConnections("datawxyawxkdvev")
- .withDisableMetricsCollection("datauuihapcqmcvur")
+ .withSource(new CopySource().withSourceRetryCount("datagylo")
+ .withSourceRetryWait("dataxwlql")
+ .withMaxConcurrentConnections("datanbudjypliotg")
+ .withDisableMetricsCollection("dataansykvlxsycq")
.withAdditionalProperties(mapOf("type", "CopySource")))
- .withSink(new CopySink().withWriteBatchSize("datadymoanpkcmdixiux")
- .withWriteBatchTimeout("datacalgspz")
- .withSinkRetryCount("datafprzlvhohzkcsjd")
- .withSinkRetryWait("dataposmnmkypeqm")
- .withMaxConcurrentConnections("dataeox")
- .withDisableMetricsCollection("datarulavxeaym")
+ .withSink(new CopySink().withWriteBatchSize("datayoonbualri")
+ .withWriteBatchTimeout("datadbnt")
+ .withSinkRetryCount("datababndwcfmz")
+ .withSinkRetryWait("datamgdlgsxkyboysquy")
+ .withMaxConcurrentConnections("datakh")
+ .withDisableMetricsCollection("datatwcyigrhfevxypqu")
.withAdditionalProperties(mapOf("type", "CopySink")))
- .withTranslator("datali")
- .withEnableStaging("datarc")
+ .withTranslator("datalq")
+ .withEnableStaging("dataa")
.withStagingSettings(new StagingSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("thluzey")
- .withParameters(mapOf("mn", "dataezkyfy", "pqegty", "dataeasuw", "tfqffwvnjg", "databycceuf", "sw",
- "datarykshizw")))
- .withPath("dataye")
- .withEnableCompression("datas")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("pwrmlv")
+ .withParameters(mapOf("xnyock", "datakkqspzw")))
+ .withPath("datassusdrgzmmrzwm")
+ .withEnableCompression("datatkcvolaxnuk")
.withAdditionalProperties(mapOf()))
- .withParallelCopies("datay")
- .withDataIntegrationUnits("dataoisbmv")
- .withEnableSkipIncompatibleRow("dataenrcqickhvps")
+ .withParallelCopies("dataezgvaeqiygbou")
+ .withDataIntegrationUnits("datajodidgudar")
+ .withEnableSkipIncompatibleRow("dataajbenf")
.withRedirectIncompatibleRowSettings(
- new RedirectIncompatibleRowSettings().withLinkedServiceName("datauiuvingmonq")
- .withPath("datatyuqdz")
+ new RedirectIncompatibleRowSettings()
+ .withLinkedServiceName("dataufvojikffczw")
+ .withPath("datawpilsuhsghdovcpb")
.withAdditionalProperties(mapOf()))
.withLogStorageSettings(new LogStorageSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("wmfwr")
- .withParameters(mapOf("vmuot", "datazg", "fyjampvwxlkh", "datasea", "ipmnqrbyq", "datarlt")))
- .withPath("datawxbowcjkargg")
- .withLogLevel("datauewgy")
- .withEnableReliableLogging("datalvxwlqlugnbudjy")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("h")
+ .withParameters(mapOf("ojker", "databomf", "togbkdctsg", "dataujfnbzamroad", "cnecl", "dataalh",
+ "nsl", "datahmjsqcubyj")))
+ .withPath("datateena")
+ .withLogLevel("dataecsft")
+ .withEnableReliableLogging("dataubzfuhj")
.withAdditionalProperties(mapOf()))
- .withLogSettings(
- new LogSettings().withEnableCopyActivityLog("dataqvpedwmhqcjreryp")
- .withCopyActivityLogSettings(new CopyActivityLogSettings().withLogLevel("dataqxeyzqnupsipclxv")
- .withEnableReliableLogging("datavss"))
- .withLogLocationSettings(new LogLocationSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("b")
- .withParameters(mapOf("icqdb", "dataq", "lrixzdbntopbab", "datazwlejiiyoonbu",
- "boysquygokh", "datadwcfmzmqmgdlgsxk", "qukcojyxhhvoo", "datastwcyigrhfevxy")))
- .withPath("datatcsucot")))
- .withPreserveRules(Arrays.asList("dataiqzjnxzvjnmpv"))
- .withPreserve(Arrays.asList("dataudfbhzuk", "datapfbhihddiiuex"))
- .withValidateDataConsistency("datayfku")
- .withSkipErrorFile(new SkipErrorFile().withFileMissing("dataqpwardpw").withDataInconsistency("datalvfisk"));
+ .withLogSettings(new LogSettings().withEnableCopyActivityLog("datakujv")
+ .withCopyActivityLogSettings(new CopyActivityLogSettings().withLogLevel("datauq")
+ .withEnableReliableLogging("datalwnxryyqtjcrpax"))
+ .withLogLocationSettings(new LogLocationSettings()
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xlfxsetvdz")
+ .withParameters(mapOf("zhdciuxotb", "datadmxfqftywbba", "hop", "dataflgkkiu", "rtaevq",
+ "datafobpyeo", "owsmrvdtqhr", "datafdhpkiiunyrobcke")))
+ .withPath("dataqs")))
+ .withPreserveRules(Arrays.asList("datanupskit", "datakphamefzzgwjoau"))
+ .withPreserve(Arrays.asList("datadpn", "dataouylfcfgqinaokx", "datauknzhmza"))
+ .withValidateDataConsistency("datarsqzuknbtxtdm")
+ .withSkipErrorFile(
+ new SkipErrorFile().withFileMissing("datarrqqajhklttl").withDataInconsistency("datawdrt"));
model = BinaryData.fromObject(model).toObject(CopyActivityTypeProperties.class);
- Assertions.assertEquals("thluzey", model.stagingSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("wmfwr", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("b", model.logSettings().logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("pwrmlv", model.stagingSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("h", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("xlfxsetvdz",
+ model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyComputeScalePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyComputeScalePropertiesTests.java
index 0486781493eb..42e9dbd9bb8a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyComputeScalePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyComputeScalePropertiesTests.java
@@ -14,20 +14,20 @@ public final class CopyComputeScalePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CopyComputeScaleProperties model = BinaryData.fromString(
- "{\"dataIntegrationUnit\":1227881123,\"timeToLive\":110823461,\"\":{\"auzbbhxncszdw\":\"datawedbpirbz\",\"ebdltniui\":\"dataaveuxgmigs\",\"hgvcy\":\"datamerf\",\"feudbobmoljirch\":\"dataddoeilhgga\"}}")
+ "{\"dataIntegrationUnit\":1175584995,\"timeToLive\":61564169,\"\":{\"yibx\":\"dataubwhx\",\"ttgxkxt\":\"dataceg\"}}")
.toObject(CopyComputeScaleProperties.class);
- Assertions.assertEquals(1227881123, model.dataIntegrationUnit());
- Assertions.assertEquals(110823461, model.timeToLive());
+ Assertions.assertEquals(1175584995, model.dataIntegrationUnit());
+ Assertions.assertEquals(61564169, model.timeToLive());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CopyComputeScaleProperties model = new CopyComputeScaleProperties().withDataIntegrationUnit(1227881123)
- .withTimeToLive(110823461)
+ CopyComputeScaleProperties model = new CopyComputeScaleProperties().withDataIntegrationUnit(1175584995)
+ .withTimeToLive(61564169)
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(CopyComputeScaleProperties.class);
- Assertions.assertEquals(1227881123, model.dataIntegrationUnit());
- Assertions.assertEquals(110823461, model.timeToLive());
+ Assertions.assertEquals(1175584995, model.dataIntegrationUnit());
+ Assertions.assertEquals(61564169, model.timeToLive());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySinkTests.java
index 1bcf6ed7fd41..5b7656a09a71 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySinkTests.java
@@ -13,18 +13,18 @@ public final class CopySinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CopySink model = BinaryData.fromString(
- "{\"type\":\"CopySink\",\"writeBatchSize\":\"datazgolfensibqi\",\"writeBatchTimeout\":\"datapyjzv\",\"sinkRetryCount\":\"dataml\",\"sinkRetryWait\":\"dataavzczvvwr\",\"maxConcurrentConnections\":\"datagalywgq\",\"disableMetricsCollection\":\"datavb\",\"\":{\"prkfvvx\":\"dataeyxewcsktvkw\",\"ypuotmkbofu\":\"dataikrjamztvnmrgv\",\"otrgyyjeagovjdun\":\"datamhksgouzvegtnph\"}}")
+ "{\"type\":\"CopySink\",\"writeBatchSize\":\"dataqibbtplrtxhz\",\"writeBatchTimeout\":\"datafwyrsfjjsoyu\",\"sinkRetryCount\":\"databuyd\",\"sinkRetryWait\":\"datahknttk\",\"maxConcurrentConnections\":\"datablehenjstiw\",\"disableMetricsCollection\":\"dataosbijikjfjibuwh\",\"\":{\"grxa\":\"datajujpifx\",\"chphovu\":\"datafjxviwxolauhr\",\"czwcxlnc\":\"datar\",\"dkbd\":\"datahywfvyriawfwws\"}}")
.toObject(CopySink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CopySink model = new CopySink().withWriteBatchSize("datazgolfensibqi")
- .withWriteBatchTimeout("datapyjzv")
- .withSinkRetryCount("dataml")
- .withSinkRetryWait("dataavzczvvwr")
- .withMaxConcurrentConnections("datagalywgq")
- .withDisableMetricsCollection("datavb")
+ CopySink model = new CopySink().withWriteBatchSize("dataqibbtplrtxhz")
+ .withWriteBatchTimeout("datafwyrsfjjsoyu")
+ .withSinkRetryCount("databuyd")
+ .withSinkRetryWait("datahknttk")
+ .withMaxConcurrentConnections("datablehenjstiw")
+ .withDisableMetricsCollection("dataosbijikjfjibuwh")
.withAdditionalProperties(mapOf("type", "CopySink"));
model = BinaryData.fromObject(model).toObject(CopySink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySourceTests.java
index b55686ae8527..a9ea9fcea135 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopySourceTests.java
@@ -13,16 +13,16 @@ public final class CopySourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CopySource model = BinaryData.fromString(
- "{\"type\":\"CopySource\",\"sourceRetryCount\":\"databz\",\"sourceRetryWait\":\"datasspwwe\",\"maxConcurrentConnections\":\"dataotbrepe\",\"disableMetricsCollection\":\"datalie\",\"\":{\"sfzgcscoot\":\"datayar\"}}")
+ "{\"type\":\"CopySource\",\"sourceRetryCount\":\"datab\",\"sourceRetryWait\":\"datapaeyw\",\"maxConcurrentConnections\":\"datatvyzuyqzjfv\",\"disableMetricsCollection\":\"datayyjvzlscyz\",\"\":{\"ssgbscq\":\"dataxmy\",\"qiparctshe\":\"dataeixazebmmjaigax\"}}")
.toObject(CopySource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CopySource model = new CopySource().withSourceRetryCount("databz")
- .withSourceRetryWait("datasspwwe")
- .withMaxConcurrentConnections("dataotbrepe")
- .withDisableMetricsCollection("datalie")
+ CopySource model = new CopySource().withSourceRetryCount("datab")
+ .withSourceRetryWait("datapaeyw")
+ .withMaxConcurrentConnections("datatvyzuyqzjfv")
+ .withDisableMetricsCollection("datayyjvzlscyz")
.withAdditionalProperties(mapOf("type", "CopySource"));
model = BinaryData.fromObject(model).toObject(CopySource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyTranslatorTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyTranslatorTests.java
index 765d299489dd..4483c5563708 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyTranslatorTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CopyTranslatorTests.java
@@ -13,7 +13,7 @@ public final class CopyTranslatorTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CopyTranslator model = BinaryData.fromString(
- "{\"type\":\"CopyTranslator\",\"\":{\"ajit\":\"datamvqichz\",\"vincnihmwvhcgc\":\"datajznpryouujqyeyzo\",\"djc\":\"datauasutdhmilhzy\"}}")
+ "{\"type\":\"CopyTranslator\",\"\":{\"ybp\":\"datanrg\",\"rvqticgsdcpmclku\":\"datawjjbmkhxun\",\"dcqrssqwzndzuxlg\":\"datadabh\"}}")
.toObject(CopyTranslator.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTests.java
index 69bd05d7a9ed..c7228306363d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTests.java
@@ -19,40 +19,33 @@ public final class CosmosDbMongoDbApiCollectionDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbMongoDbApiCollectionDataset model = BinaryData.fromString(
- "{\"type\":\"CosmosDbMongoDbApiCollection\",\"typeProperties\":{\"collection\":\"datazxjziuu\"},\"description\":\"lnewnuwkkfz\",\"structure\":\"datatlvhdyxzl\",\"schema\":\"dataywj\",\"linkedServiceName\":{\"referenceName\":\"rlgqp\",\"parameters\":{\"xeba\":\"datazpddarcbcdwhs\",\"oprwkampyh\":\"dataadknmstb\",\"iudrcycmwhuzym\":\"datapbldz\"}},\"parameters\":{\"dcp\":{\"type\":\"Int\",\"defaultValue\":\"dataqknlvkmnbzkopaii\"},\"drobujnjgy\":{\"type\":\"Bool\",\"defaultValue\":\"datahquxsyjofpgv\"},\"gid\":{\"type\":\"Object\",\"defaultValue\":\"datamqx\"},\"kgrhnytslgsazuqz\":{\"type\":\"Array\",\"defaultValue\":\"datanjgcp\"}},\"annotations\":[\"dataxhkyqzjsdkpv\",\"datarvzw\"],\"folder\":{\"name\":\"xsfybntmveho\"},\"\":{\"dybnairvhpqsvb\":\"datayuvbgtzqzqweu\",\"trcnqnvnc\":\"dataeoge\",\"vjnkoiz\":\"datarfcs\",\"mvwrmjxyvuodnx\":\"datazsqbibaaugicovj\"}}")
+ "{\"type\":\"CosmosDbMongoDbApiCollection\",\"typeProperties\":{\"collection\":\"databpebrmj\"},\"description\":\"fpghtbttpkim\",\"structure\":\"datahnkkhbykrs\",\"schema\":\"datarcmelycpgokut\",\"linkedServiceName\":{\"referenceName\":\"rvybnz\",\"parameters\":{\"ixlvzcgul\":\"datamshfuzzlap\",\"wjt\":\"dataebxiauqsuptessj\",\"skxgxqaygas\":\"datatpvb\",\"wpvlcjbvyezjwjkq\":\"datakvc\"}},\"parameters\":{\"fpucwn\":{\"type\":\"Bool\",\"defaultValue\":\"dataiieyozvrc\"}},\"annotations\":[\"dataqefgzjvbx\",\"datacbgoarxtuuciagv\",\"datadlhuduklbjo\",\"datafmjfexulv\"],\"folder\":{\"name\":\"kna\"},\"\":{\"leqfgkxenvszg\":\"dataiancsqoacbuqdgsa\",\"eszsuuv\":\"datavya\",\"brveci\":\"datalaqcwggchxvlqg\"}}")
.toObject(CosmosDbMongoDbApiCollectionDataset.class);
- Assertions.assertEquals("lnewnuwkkfz", model.description());
- Assertions.assertEquals("rlgqp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("dcp").type());
- Assertions.assertEquals("xsfybntmveho", model.folder().name());
+ Assertions.assertEquals("fpghtbttpkim", model.description());
+ Assertions.assertEquals("rvybnz", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("fpucwn").type());
+ Assertions.assertEquals("kna", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CosmosDbMongoDbApiCollectionDataset model
- = new CosmosDbMongoDbApiCollectionDataset().withDescription("lnewnuwkkfz")
- .withStructure("datatlvhdyxzl")
- .withSchema("dataywj")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rlgqp")
- .withParameters(mapOf("xeba", "datazpddarcbcdwhs", "oprwkampyh", "dataadknmstb", "iudrcycmwhuzym",
- "datapbldz")))
- .withParameters(
- mapOf("dcp",
- new ParameterSpecification().withType(ParameterType.INT)
- .withDefaultValue("dataqknlvkmnbzkopaii"),
- "drobujnjgy",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datahquxsyjofpgv"),
- "gid", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datamqx"),
- "kgrhnytslgsazuqz",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanjgcp")))
- .withAnnotations(Arrays.asList("dataxhkyqzjsdkpv", "datarvzw"))
- .withFolder(new DatasetFolder().withName("xsfybntmveho"))
- .withCollection("datazxjziuu");
+ CosmosDbMongoDbApiCollectionDataset model = new CosmosDbMongoDbApiCollectionDataset()
+ .withDescription("fpghtbttpkim")
+ .withStructure("datahnkkhbykrs")
+ .withSchema("datarcmelycpgokut")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rvybnz")
+ .withParameters(mapOf("ixlvzcgul", "datamshfuzzlap", "wjt", "dataebxiauqsuptessj", "skxgxqaygas",
+ "datatpvb", "wpvlcjbvyezjwjkq", "datakvc")))
+ .withParameters(mapOf("fpucwn",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataiieyozvrc")))
+ .withAnnotations(Arrays.asList("dataqefgzjvbx", "datacbgoarxtuuciagv", "datadlhuduklbjo", "datafmjfexulv"))
+ .withFolder(new DatasetFolder().withName("kna"))
+ .withCollection("databpebrmj");
model = BinaryData.fromObject(model).toObject(CosmosDbMongoDbApiCollectionDataset.class);
- Assertions.assertEquals("lnewnuwkkfz", model.description());
- Assertions.assertEquals("rlgqp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("dcp").type());
- Assertions.assertEquals("xsfybntmveho", model.folder().name());
+ Assertions.assertEquals("fpghtbttpkim", model.description());
+ Assertions.assertEquals("rvybnz", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("fpucwn").type());
+ Assertions.assertEquals("kna", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTypePropertiesTests.java
index b39d5599843e..b47c427606a7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiCollectionDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class CosmosDbMongoDbApiCollectionDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbMongoDbApiCollectionDatasetTypeProperties model
- = BinaryData.fromString("{\"collection\":\"datazbassqfyy\"}")
+ = BinaryData.fromString("{\"collection\":\"dataaovphirlzbipi\"}")
.toObject(CosmosDbMongoDbApiCollectionDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
CosmosDbMongoDbApiCollectionDatasetTypeProperties model
- = new CosmosDbMongoDbApiCollectionDatasetTypeProperties().withCollection("datazbassqfyy");
+ = new CosmosDbMongoDbApiCollectionDatasetTypeProperties().withCollection("dataaovphirlzbipi");
model = BinaryData.fromObject(model).toObject(CosmosDbMongoDbApiCollectionDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTests.java
index 8c9258d75c9f..fe3653184de9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTests.java
@@ -18,35 +18,35 @@ public final class CosmosDbMongoDbApiLinkedServiceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbMongoDbApiLinkedService model = BinaryData.fromString(
- "{\"type\":\"CosmosDbMongoDbApi\",\"typeProperties\":{\"isServerVersionAbove32\":\"dataikcgittfm\",\"connectionString\":\"datapihtepasjeb\",\"database\":\"datainvfcdsijsinybn\"},\"version\":\"x\",\"connectVia\":{\"referenceName\":\"yxujzoxg\",\"parameters\":{\"uc\":\"datatkr\",\"hulxgce\":\"datazwedm\",\"anudvqannenxg\":\"datax\",\"b\":\"datahmmgblqyfg\"}},\"description\":\"qifsgzfgxwfxji\",\"parameters\":{\"yooghjxhp\":{\"type\":\"Object\",\"defaultValue\":\"datahwnn\"},\"hoyg\":{\"type\":\"Object\",\"defaultValue\":\"dataksqiwlmegjtose\"},\"zzugdorc\":{\"type\":\"Float\",\"defaultValue\":\"dataz\"}},\"annotations\":[\"datavovsirtasepi\"],\"\":{\"amnvrcqjpbainsih\":\"dataexhhjjatlepzbiro\",\"eufj\":\"dataz\",\"zm\":\"datab\"}}")
+ "{\"type\":\"CosmosDbMongoDbApi\",\"typeProperties\":{\"isServerVersionAbove32\":\"dataopqqiyjrehe\",\"connectionString\":\"datachengmxpjkuq\",\"database\":\"datangromlxsqdzyyalr\"},\"version\":\"gq\",\"connectVia\":{\"referenceName\":\"fwuplfjkbax\",\"parameters\":{\"hxbfhbip\":\"dataeimuipggt\",\"fefznxcleyamv\":\"datadziphe\",\"vbtkafcnfitpu\":\"dataitjjhqvypqgncgw\"}},\"description\":\"ykdwyjd\",\"parameters\":{\"yngoudclri\":{\"type\":\"Bool\",\"defaultValue\":\"dataawj\"},\"chgjonrhdib\":{\"type\":\"Object\",\"defaultValue\":\"dataynxbdisjeovgcf\"},\"y\":{\"type\":\"Int\",\"defaultValue\":\"datad\"},\"njbbhwsfllzy\":{\"type\":\"SecureString\",\"defaultValue\":\"dataouiuvkcnq\"}},\"annotations\":[\"dataj\"],\"\":{\"jsgbpj\":\"datalpby\",\"vwbd\":\"datanblbkakn\",\"qilsbabqtjch\":\"datanddctkjcqhxdirt\",\"eiyem\":\"datasfwey\"}}")
.toObject(CosmosDbMongoDbApiLinkedService.class);
- Assertions.assertEquals("x", model.version());
- Assertions.assertEquals("yxujzoxg", model.connectVia().referenceName());
- Assertions.assertEquals("qifsgzfgxwfxji", model.description());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("yooghjxhp").type());
+ Assertions.assertEquals("gq", model.version());
+ Assertions.assertEquals("fwuplfjkbax", model.connectVia().referenceName());
+ Assertions.assertEquals("ykdwyjd", model.description());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("yngoudclri").type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CosmosDbMongoDbApiLinkedService model
- = new CosmosDbMongoDbApiLinkedService().withVersion("x")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("yxujzoxg")
- .withParameters(mapOf("uc", "datatkr", "hulxgce", "datazwedm", "anudvqannenxg", "datax", "b",
- "datahmmgblqyfg")))
- .withDescription("qifsgzfgxwfxji")
- .withParameters(mapOf("yooghjxhp",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datahwnn"), "hoyg",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataksqiwlmegjtose"),
- "zzugdorc", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataz")))
- .withAnnotations(Arrays.asList("datavovsirtasepi"))
- .withIsServerVersionAbove32("dataikcgittfm")
- .withConnectionString("datapihtepasjeb")
- .withDatabase("datainvfcdsijsinybn");
+ CosmosDbMongoDbApiLinkedService model = new CosmosDbMongoDbApiLinkedService().withVersion("gq")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("fwuplfjkbax")
+ .withParameters(mapOf("hxbfhbip", "dataeimuipggt", "fefznxcleyamv", "datadziphe", "vbtkafcnfitpu",
+ "dataitjjhqvypqgncgw")))
+ .withDescription("ykdwyjd")
+ .withParameters(mapOf("yngoudclri",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataawj"), "chgjonrhdib",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataynxbdisjeovgcf"), "y",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datad"), "njbbhwsfllzy",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataouiuvkcnq")))
+ .withAnnotations(Arrays.asList("dataj"))
+ .withIsServerVersionAbove32("dataopqqiyjrehe")
+ .withConnectionString("datachengmxpjkuq")
+ .withDatabase("datangromlxsqdzyyalr");
model = BinaryData.fromObject(model).toObject(CosmosDbMongoDbApiLinkedService.class);
- Assertions.assertEquals("x", model.version());
- Assertions.assertEquals("yxujzoxg", model.connectVia().referenceName());
- Assertions.assertEquals("qifsgzfgxwfxji", model.description());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("yooghjxhp").type());
+ Assertions.assertEquals("gq", model.version());
+ Assertions.assertEquals("fwuplfjkbax", model.connectVia().referenceName());
+ Assertions.assertEquals("ykdwyjd", model.description());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("yngoudclri").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTypePropertiesTests.java
index 6d11545a4af9..4e7a59723f02 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiLinkedServiceTypePropertiesTests.java
@@ -11,16 +11,16 @@ public final class CosmosDbMongoDbApiLinkedServiceTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbMongoDbApiLinkedServiceTypeProperties model = BinaryData.fromString(
- "{\"isServerVersionAbove32\":\"datadmppibvwqjcph\",\"connectionString\":\"datafyoqfvmvw\",\"database\":\"datal\"}")
+ "{\"isServerVersionAbove32\":\"datapszekdqqwcspf\",\"connectionString\":\"datarndqymloslqgs\",\"database\":\"dataqnqqzqdvg\"}")
.toObject(CosmosDbMongoDbApiLinkedServiceTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
CosmosDbMongoDbApiLinkedServiceTypeProperties model
- = new CosmosDbMongoDbApiLinkedServiceTypeProperties().withIsServerVersionAbove32("datadmppibvwqjcph")
- .withConnectionString("datafyoqfvmvw")
- .withDatabase("datal");
+ = new CosmosDbMongoDbApiLinkedServiceTypeProperties().withIsServerVersionAbove32("datapszekdqqwcspf")
+ .withConnectionString("datarndqymloslqgs")
+ .withDatabase("dataqnqqzqdvg");
model = BinaryData.fromObject(model).toObject(CosmosDbMongoDbApiLinkedServiceTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSinkTests.java
index 6a6890e6beb1..16303fe5a691 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSinkTests.java
@@ -11,19 +11,19 @@ public final class CosmosDbMongoDbApiSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbMongoDbApiSink model = BinaryData.fromString(
- "{\"type\":\"CosmosDbMongoDbApiSink\",\"writeBehavior\":\"dataotrwldeinhn\",\"writeBatchSize\":\"datagmu\",\"writeBatchTimeout\":\"datatqnqmsiptzg\",\"sinkRetryCount\":\"dataujukenk\",\"sinkRetryWait\":\"dataombkg\",\"maxConcurrentConnections\":\"dataobuihprvokodrpy\",\"disableMetricsCollection\":\"datazxr\",\"\":{\"y\":\"dataycufk\",\"aeu\":\"dataxoubekafdxgtgcfk\",\"tlk\":\"datam\",\"uxvjjwlwysrswzh\":\"datafpqebbqetx\"}}")
+ "{\"type\":\"CosmosDbMongoDbApiSink\",\"writeBehavior\":\"dataeszx\",\"writeBatchSize\":\"datageuoihtik\",\"writeBatchTimeout\":\"datawp\",\"sinkRetryCount\":\"datayavcbdsuwctvbhc\",\"sinkRetryWait\":\"datagxtljyrey\",\"maxConcurrentConnections\":\"databtwzrzi\",\"disableMetricsCollection\":\"datak\",\"\":{\"buyuxg\":\"datajymdol\",\"sdoxhyi\":\"dataphviuexfb\",\"fkmti\":\"dataagaxru\"}}")
.toObject(CosmosDbMongoDbApiSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CosmosDbMongoDbApiSink model = new CosmosDbMongoDbApiSink().withWriteBatchSize("datagmu")
- .withWriteBatchTimeout("datatqnqmsiptzg")
- .withSinkRetryCount("dataujukenk")
- .withSinkRetryWait("dataombkg")
- .withMaxConcurrentConnections("dataobuihprvokodrpy")
- .withDisableMetricsCollection("datazxr")
- .withWriteBehavior("dataotrwldeinhn");
+ CosmosDbMongoDbApiSink model = new CosmosDbMongoDbApiSink().withWriteBatchSize("datageuoihtik")
+ .withWriteBatchTimeout("datawp")
+ .withSinkRetryCount("datayavcbdsuwctvbhc")
+ .withSinkRetryWait("datagxtljyrey")
+ .withMaxConcurrentConnections("databtwzrzi")
+ .withDisableMetricsCollection("datak")
+ .withWriteBehavior("dataeszx");
model = BinaryData.fromObject(model).toObject(CosmosDbMongoDbApiSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSourceTests.java
index fa1e741d3b0f..354e49cc74e0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbMongoDbApiSourceTests.java
@@ -14,25 +14,25 @@ public final class CosmosDbMongoDbApiSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbMongoDbApiSource model = BinaryData.fromString(
- "{\"type\":\"CosmosDbMongoDbApiSource\",\"filter\":\"datauysszhsewjqg\",\"cursorMethods\":{\"project\":\"dataorhxdureg\",\"sort\":\"dataqpyxia\",\"skip\":\"datagdkanmhvwgchgp\",\"limit\":\"datakqw\",\"\":{\"qvectooxjztta\":\"datamapcaxnoqnjfv\",\"mdyb\":\"datasnmxvsrvkzvxlez\",\"ogtnfla\":\"dataehjk\",\"q\":\"dataspghfv\"}},\"batchSize\":\"datamyqosrsfaocrr\",\"queryTimeout\":\"datarg\",\"additionalColumns\":\"datayoh\",\"sourceRetryCount\":\"dataruvvlwhtfscoup\",\"sourceRetryWait\":\"dataeywbhxhawkwcf\",\"maxConcurrentConnections\":\"dataqexd\",\"disableMetricsCollection\":\"datacvkwwjjotfun\",\"\":{\"fuobx\":\"dataejxvrwalekqed\",\"fjibbl\":\"datalainzvhl\",\"egzyzlslvgqlexw\":\"dataihvzdaycme\",\"t\":\"datawbbellcjd\"}}")
+ "{\"type\":\"CosmosDbMongoDbApiSource\",\"filter\":\"datahlkzt\",\"cursorMethods\":{\"project\":\"datauupcdao\",\"sort\":\"datazvajwvxhefmotul\",\"skip\":\"datalmazgpqo\",\"limit\":\"datapsoeocvywtyehln\",\"\":{\"wdxoxjlvvvzpjjv\":\"dataeplyosadxs\",\"mb\":\"dataintgkveogeld\"}},\"batchSize\":\"databii\",\"queryTimeout\":\"databkxiujaagfeiwuux\",\"additionalColumns\":\"datamzmsivqeg\",\"sourceRetryCount\":\"datafzbrha\",\"sourceRetryWait\":\"dataptkr\",\"maxConcurrentConnections\":\"dataspz\",\"disableMetricsCollection\":\"dataev\",\"\":{\"xyoyjasqdhbftt\":\"dataszcau\"}}")
.toObject(CosmosDbMongoDbApiSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CosmosDbMongoDbApiSource model = new CosmosDbMongoDbApiSource().withSourceRetryCount("dataruvvlwhtfscoup")
- .withSourceRetryWait("dataeywbhxhawkwcf")
- .withMaxConcurrentConnections("dataqexd")
- .withDisableMetricsCollection("datacvkwwjjotfun")
- .withFilter("datauysszhsewjqg")
- .withCursorMethods(new MongoDbCursorMethodsProperties().withProject("dataorhxdureg")
- .withSort("dataqpyxia")
- .withSkip("datagdkanmhvwgchgp")
- .withLimit("datakqw")
+ CosmosDbMongoDbApiSource model = new CosmosDbMongoDbApiSource().withSourceRetryCount("datafzbrha")
+ .withSourceRetryWait("dataptkr")
+ .withMaxConcurrentConnections("dataspz")
+ .withDisableMetricsCollection("dataev")
+ .withFilter("datahlkzt")
+ .withCursorMethods(new MongoDbCursorMethodsProperties().withProject("datauupcdao")
+ .withSort("datazvajwvxhefmotul")
+ .withSkip("datalmazgpqo")
+ .withLimit("datapsoeocvywtyehln")
.withAdditionalProperties(mapOf()))
- .withBatchSize("datamyqosrsfaocrr")
- .withQueryTimeout("datarg")
- .withAdditionalColumns("datayoh");
+ .withBatchSize("databii")
+ .withQueryTimeout("databkxiujaagfeiwuux")
+ .withAdditionalColumns("datamzmsivqeg");
model = BinaryData.fromObject(model).toObject(CosmosDbMongoDbApiSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTests.java
index faeb87b2ec1f..712d50580491 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTests.java
@@ -19,32 +19,32 @@ public final class CosmosDbSqlApiCollectionDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbSqlApiCollectionDataset model = BinaryData.fromString(
- "{\"type\":\"CosmosDbSqlApiCollection\",\"typeProperties\":{\"collectionName\":\"dataavdostw\"},\"description\":\"ufmwelvx\",\"structure\":\"datazzkw\",\"schema\":\"datalcjgpvcqzvzrbvg\",\"linkedServiceName\":{\"referenceName\":\"x\",\"parameters\":{\"drwynbgovazoym\":\"datarmxv\"}},\"parameters\":{\"dkatveqmgk\":{\"type\":\"String\",\"defaultValue\":\"datalkhw\"},\"buklvsmfasg\":{\"type\":\"Bool\",\"defaultValue\":\"datazeyxryearmhp\"}},\"annotations\":[\"datahqpoilosja\"],\"folder\":{\"name\":\"ez\"},\"\":{\"kjyghztms\":\"datatmhllp\"}}")
+ "{\"type\":\"CosmosDbSqlApiCollection\",\"typeProperties\":{\"collectionName\":\"datawpad\"},\"description\":\"dbfobdc\",\"structure\":\"dataothm\",\"schema\":\"datajaoz\",\"linkedServiceName\":{\"referenceName\":\"bwfcn\",\"parameters\":{\"lhscmyh\":\"datapo\",\"okndwpppqwojoevz\":\"datahjvszfq\",\"zlyvapbkrbuog\":\"dataufytdxmly\",\"cuhaizijv\":\"datatdlt\"}},\"parameters\":{\"m\":{\"type\":\"Float\",\"defaultValue\":\"dataohlpsftqkr\"}},\"annotations\":[\"datavvcpwtqsuspn\",\"datamzy\"],\"folder\":{\"name\":\"etevrntfknwacy\"},\"\":{\"atvcsxr\":\"dataotctkhfhf\",\"cubleh\":\"datahnmizhvprhqq\"}}")
.toObject(CosmosDbSqlApiCollectionDataset.class);
- Assertions.assertEquals("ufmwelvx", model.description());
- Assertions.assertEquals("x", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("dkatveqmgk").type());
- Assertions.assertEquals("ez", model.folder().name());
+ Assertions.assertEquals("dbfobdc", model.description());
+ Assertions.assertEquals("bwfcn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("m").type());
+ Assertions.assertEquals("etevrntfknwacy", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CosmosDbSqlApiCollectionDataset model = new CosmosDbSqlApiCollectionDataset().withDescription("ufmwelvx")
- .withStructure("datazzkw")
- .withSchema("datalcjgpvcqzvzrbvg")
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("x").withParameters(mapOf("drwynbgovazoym", "datarmxv")))
- .withParameters(mapOf("dkatveqmgk",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datalkhw"), "buklvsmfasg",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datazeyxryearmhp")))
- .withAnnotations(Arrays.asList("datahqpoilosja"))
- .withFolder(new DatasetFolder().withName("ez"))
- .withCollectionName("dataavdostw");
+ CosmosDbSqlApiCollectionDataset model = new CosmosDbSqlApiCollectionDataset().withDescription("dbfobdc")
+ .withStructure("dataothm")
+ .withSchema("datajaoz")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bwfcn")
+ .withParameters(mapOf("lhscmyh", "datapo", "okndwpppqwojoevz", "datahjvszfq", "zlyvapbkrbuog",
+ "dataufytdxmly", "cuhaizijv", "datatdlt")))
+ .withParameters(mapOf("m",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataohlpsftqkr")))
+ .withAnnotations(Arrays.asList("datavvcpwtqsuspn", "datamzy"))
+ .withFolder(new DatasetFolder().withName("etevrntfknwacy"))
+ .withCollectionName("datawpad");
model = BinaryData.fromObject(model).toObject(CosmosDbSqlApiCollectionDataset.class);
- Assertions.assertEquals("ufmwelvx", model.description());
- Assertions.assertEquals("x", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("dkatveqmgk").type());
- Assertions.assertEquals("ez", model.folder().name());
+ Assertions.assertEquals("dbfobdc", model.description());
+ Assertions.assertEquals("bwfcn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("m").type());
+ Assertions.assertEquals("etevrntfknwacy", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTypePropertiesTests.java
index 12c47168d4fe..263dc932dd7c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiCollectionDatasetTypePropertiesTests.java
@@ -10,14 +10,15 @@
public final class CosmosDbSqlApiCollectionDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- CosmosDbSqlApiCollectionDatasetTypeProperties model = BinaryData.fromString("{\"collectionName\":\"dataiwtp\"}")
- .toObject(CosmosDbSqlApiCollectionDatasetTypeProperties.class);
+ CosmosDbSqlApiCollectionDatasetTypeProperties model
+ = BinaryData.fromString("{\"collectionName\":\"datakplobzgottaksadz\"}")
+ .toObject(CosmosDbSqlApiCollectionDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
CosmosDbSqlApiCollectionDatasetTypeProperties model
- = new CosmosDbSqlApiCollectionDatasetTypeProperties().withCollectionName("dataiwtp");
+ = new CosmosDbSqlApiCollectionDatasetTypeProperties().withCollectionName("datakplobzgottaksadz");
model = BinaryData.fromObject(model).toObject(CosmosDbSqlApiCollectionDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSinkTests.java
index a83117f43257..43a4f75c3440 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSinkTests.java
@@ -11,19 +11,19 @@ public final class CosmosDbSqlApiSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbSqlApiSink model = BinaryData.fromString(
- "{\"type\":\"CosmosDbSqlApiSink\",\"writeBehavior\":\"datato\",\"writeBatchSize\":\"dataxojijttsyrxynnfs\",\"writeBatchTimeout\":\"dataycissh\",\"sinkRetryCount\":\"dataxft\",\"sinkRetryWait\":\"datafcduqsdurfqaawr\",\"maxConcurrentConnections\":\"datatzslfrztpnry\",\"disableMetricsCollection\":\"dataxajr\",\"\":{\"esowbtnfqlwcaxj\":\"dataghlhddvno\",\"cmeuuuajiotl\":\"datahteho\",\"kqtiuve\":\"dataxofqjninrskq\"}}")
+ "{\"type\":\"CosmosDbSqlApiSink\",\"writeBehavior\":\"datapiezthflgpsalyn\",\"writeBatchSize\":\"datamwzpfbiqjrz\",\"writeBatchTimeout\":\"dataxizorqliblyb\",\"sinkRetryCount\":\"datajzknkffzdyozn\",\"sinkRetryWait\":\"datastofdedlmfwabf\",\"maxConcurrentConnections\":\"datawe\",\"disableMetricsCollection\":\"datawxmcsxidazslwhuy\",\"\":{\"fperheiplzms\":\"datadcilinbuok\",\"u\":\"datahqrdvqvalo\",\"fjgklmyomav\":\"datawoigofumbpmzed\"}}")
.toObject(CosmosDbSqlApiSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CosmosDbSqlApiSink model = new CosmosDbSqlApiSink().withWriteBatchSize("dataxojijttsyrxynnfs")
- .withWriteBatchTimeout("dataycissh")
- .withSinkRetryCount("dataxft")
- .withSinkRetryWait("datafcduqsdurfqaawr")
- .withMaxConcurrentConnections("datatzslfrztpnry")
- .withDisableMetricsCollection("dataxajr")
- .withWriteBehavior("datato");
+ CosmosDbSqlApiSink model = new CosmosDbSqlApiSink().withWriteBatchSize("datamwzpfbiqjrz")
+ .withWriteBatchTimeout("dataxizorqliblyb")
+ .withSinkRetryCount("datajzknkffzdyozn")
+ .withSinkRetryWait("datastofdedlmfwabf")
+ .withMaxConcurrentConnections("datawe")
+ .withDisableMetricsCollection("datawxmcsxidazslwhuy")
+ .withWriteBehavior("datapiezthflgpsalyn");
model = BinaryData.fromObject(model).toObject(CosmosDbSqlApiSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSourceTests.java
index f95ebee9ea7a..fb8cd58f88bd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CosmosDbSqlApiSourceTests.java
@@ -11,21 +11,21 @@ public final class CosmosDbSqlApiSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CosmosDbSqlApiSource model = BinaryData.fromString(
- "{\"type\":\"CosmosDbSqlApiSource\",\"query\":\"datamsptcesvvr\",\"pageSize\":\"databyfhzybjrxen\",\"preferredRegions\":\"dataxanlbrcydwrc\",\"detectDatetime\":\"dataanbw\",\"additionalColumns\":\"datalqioq\",\"sourceRetryCount\":\"dataxcg\",\"sourceRetryWait\":\"datazluilzgpghjakzmn\",\"maxConcurrentConnections\":\"datanqmajs\",\"disableMetricsCollection\":\"datamjlp\",\"\":{\"ojrwpoxuy\":\"datapfyup\",\"gtxwyqkkdumxdrg\":\"dataqyoyjptkyfrk\",\"ovfundk\":\"datamsioffyboon\",\"nugcbjxgjudg\":\"datadmyxmsbtqhh\"}}")
+ "{\"type\":\"CosmosDbSqlApiSource\",\"query\":\"dataloqpgzdbonepp\",\"pageSize\":\"datamzeufjzqaq\",\"preferredRegions\":\"datacbygqcwzyto\",\"detectDatetime\":\"dataqcthgqyvaoaz\",\"additionalColumns\":\"dataykkcqaf\",\"sourceRetryCount\":\"datajgixsjhi\",\"sourceRetryWait\":\"datayekslllzsqolckwh\",\"maxConcurrentConnections\":\"datafbnnhwpnloi\",\"disableMetricsCollection\":\"datazdohfvxavhfhl\",\"\":{\"cfrfaytcygoombn\":\"datawzpba\",\"wltozxdzoldwv\":\"datambcklfpemgfvvnk\",\"regesoozpudalu\":\"datanpnyaterjjuz\"}}")
.toObject(CosmosDbSqlApiSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CosmosDbSqlApiSource model = new CosmosDbSqlApiSource().withSourceRetryCount("dataxcg")
- .withSourceRetryWait("datazluilzgpghjakzmn")
- .withMaxConcurrentConnections("datanqmajs")
- .withDisableMetricsCollection("datamjlp")
- .withQuery("datamsptcesvvr")
- .withPageSize("databyfhzybjrxen")
- .withPreferredRegions("dataxanlbrcydwrc")
- .withDetectDatetime("dataanbw")
- .withAdditionalColumns("datalqioq");
+ CosmosDbSqlApiSource model = new CosmosDbSqlApiSource().withSourceRetryCount("datajgixsjhi")
+ .withSourceRetryWait("datayekslllzsqolckwh")
+ .withMaxConcurrentConnections("datafbnnhwpnloi")
+ .withDisableMetricsCollection("datazdohfvxavhfhl")
+ .withQuery("dataloqpgzdbonepp")
+ .withPageSize("datamzeufjzqaq")
+ .withPreferredRegions("datacbygqcwzyto")
+ .withDetectDatetime("dataqcthgqyvaoaz")
+ .withAdditionalColumns("dataykkcqaf");
model = BinaryData.fromObject(model).toObject(CosmosDbSqlApiSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseSourceTests.java
index 1527c0c532c8..c61eb5fad609 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseSourceTests.java
@@ -11,19 +11,19 @@ public final class CouchbaseSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CouchbaseSource model = BinaryData.fromString(
- "{\"type\":\"CouchbaseSource\",\"query\":\"datadhismwjkq\",\"queryTimeout\":\"datayuygybshch\",\"additionalColumns\":\"dataeaitzgewwqwibt\",\"sourceRetryCount\":\"datahcgbzrlf\",\"sourceRetryWait\":\"datawusqupk\",\"maxConcurrentConnections\":\"datappmwozwjinxyrtec\",\"disableMetricsCollection\":\"datazslttk\",\"\":{\"mahuw\":\"datakujceeczhsdpfoa\",\"ewrryt\":\"dataodddq\",\"s\":\"datasocqkdclbzqnao\",\"cbhezau\":\"datamp\"}}")
+ "{\"type\":\"CouchbaseSource\",\"query\":\"datahndfpf\",\"queryTimeout\":\"datafdgf\",\"additionalColumns\":\"dataoeh\",\"sourceRetryCount\":\"datapkssjbw\",\"sourceRetryWait\":\"dataxdgcfcfky\",\"maxConcurrentConnections\":\"datajwxhslrbwwk\",\"disableMetricsCollection\":\"datawodhsodofsxjiky\",\"\":{\"cxdmxhuwldfa\":\"datauhuixqwogg\",\"dkbgsg\":\"datakyft\",\"ayqkg\":\"datapyckmncrutoudjm\"}}")
.toObject(CouchbaseSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CouchbaseSource model = new CouchbaseSource().withSourceRetryCount("datahcgbzrlf")
- .withSourceRetryWait("datawusqupk")
- .withMaxConcurrentConnections("datappmwozwjinxyrtec")
- .withDisableMetricsCollection("datazslttk")
- .withQueryTimeout("datayuygybshch")
- .withAdditionalColumns("dataeaitzgewwqwibt")
- .withQuery("datadhismwjkq");
+ CouchbaseSource model = new CouchbaseSource().withSourceRetryCount("datapkssjbw")
+ .withSourceRetryWait("dataxdgcfcfky")
+ .withMaxConcurrentConnections("datajwxhslrbwwk")
+ .withDisableMetricsCollection("datawodhsodofsxjiky")
+ .withQueryTimeout("datafdgf")
+ .withAdditionalColumns("dataoeh")
+ .withQuery("datahndfpf");
model = BinaryData.fromObject(model).toObject(CouchbaseSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseTableDatasetTests.java
index 499bd0dbbf1d..a27053fb67f2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CouchbaseTableDatasetTests.java
@@ -19,33 +19,34 @@ public final class CouchbaseTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CouchbaseTableDataset model = BinaryData.fromString(
- "{\"type\":\"CouchbaseTable\",\"typeProperties\":{\"tableName\":\"datafybxmmrvn\"},\"description\":\"qkrrsguogkcb\",\"structure\":\"datatpyabensjflwp\",\"schema\":\"datavvqtmvif\",\"linkedServiceName\":{\"referenceName\":\"cv\",\"parameters\":{\"t\":\"dataalb\"}},\"parameters\":{\"hmvjcnnlsb\":{\"type\":\"Int\",\"defaultValue\":\"datasnxajptcdfmzxaox\"},\"ovlznklel\":{\"type\":\"Float\",\"defaultValue\":\"dataqxhpaqoqbvejoyso\"}},\"annotations\":[\"datadlqqhn\",\"dataqrykkxakruupti\",\"datacg\",\"datapz\"],\"folder\":{\"name\":\"ccnpxiemacmzt\"},\"\":{\"ocnqbblr\":\"dataxsnnbrysgktf\",\"fwxud\":\"databofzghfu\",\"cqxu\":\"datanoh\"}}")
+ "{\"type\":\"CouchbaseTable\",\"typeProperties\":{\"tableName\":\"datacaujbfomf\"},\"description\":\"zpjyxefppqcwd\",\"structure\":\"datajj\",\"schema\":\"datapsnxebycympohxub\",\"linkedServiceName\":{\"referenceName\":\"n\",\"parameters\":{\"usp\":\"dataebcxn\",\"vgspjlfzhjngwqx\":\"datayzssjlmykdyg\"}},\"parameters\":{\"c\":{\"type\":\"Bool\",\"defaultValue\":\"datagyoimmsszz\"},\"nwcnvpnyldjdkj\":{\"type\":\"SecureString\",\"defaultValue\":\"dataognhtvagw\"}},\"annotations\":[\"datayknkxioxhnrjlq\"],\"folder\":{\"name\":\"ejexfdlhuhd\"},\"\":{\"cflvxbocaywmfvuh\":\"datagywadrklpdyehjr\",\"gsfmhwdxqu\":\"datamolhveol\",\"ynhitrnwqgq\":\"dataymlhklmnjqzm\",\"piqnrjoc\":\"databthb\"}}")
.toObject(CouchbaseTableDataset.class);
- Assertions.assertEquals("qkrrsguogkcb", model.description());
- Assertions.assertEquals("cv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("hmvjcnnlsb").type());
- Assertions.assertEquals("ccnpxiemacmzt", model.folder().name());
+ Assertions.assertEquals("zpjyxefppqcwd", model.description());
+ Assertions.assertEquals("n", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("c").type());
+ Assertions.assertEquals("ejexfdlhuhd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CouchbaseTableDataset model = new CouchbaseTableDataset().withDescription("qkrrsguogkcb")
- .withStructure("datatpyabensjflwp")
- .withSchema("datavvqtmvif")
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("cv").withParameters(mapOf("t", "dataalb")))
- .withParameters(mapOf("hmvjcnnlsb",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datasnxajptcdfmzxaox"),
- "ovlznklel",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqxhpaqoqbvejoyso")))
- .withAnnotations(Arrays.asList("datadlqqhn", "dataqrykkxakruupti", "datacg", "datapz"))
- .withFolder(new DatasetFolder().withName("ccnpxiemacmzt"))
- .withTableName("datafybxmmrvn");
+ CouchbaseTableDataset model = new CouchbaseTableDataset().withDescription("zpjyxefppqcwd")
+ .withStructure("datajj")
+ .withSchema("datapsnxebycympohxub")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("n")
+ .withParameters(mapOf("usp", "dataebcxn", "vgspjlfzhjngwqx", "datayzssjlmykdyg")))
+ .withParameters(
+ mapOf("c", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datagyoimmsszz"),
+ "nwcnvpnyldjdkj",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("dataognhtvagw")))
+ .withAnnotations(Arrays.asList("datayknkxioxhnrjlq"))
+ .withFolder(new DatasetFolder().withName("ejexfdlhuhd"))
+ .withTableName("datacaujbfomf");
model = BinaryData.fromObject(model).toObject(CouchbaseTableDataset.class);
- Assertions.assertEquals("qkrrsguogkcb", model.description());
- Assertions.assertEquals("cv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("hmvjcnnlsb").type());
- Assertions.assertEquals("ccnpxiemacmzt", model.folder().name());
+ Assertions.assertEquals("zpjyxefppqcwd", model.description());
+ Assertions.assertEquals("n", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("c").type());
+ Assertions.assertEquals("ejexfdlhuhd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsCreateOrUpdateWithResponseMockTests.java
index a16dfe593891..fa7f93c435a8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsCreateOrUpdateWithResponseMockTests.java
@@ -25,7 +25,7 @@ public final class CredentialOperationsCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"Credential\",\"description\":\"rgwmge\",\"annotations\":[\"datairnfnlyvdryx\",\"datauqwtazuacawxs\",\"datas\"],\"\":{\"xycvoexbxr\":\"databbqqtvp\",\"acgmnelozzfwyegd\":\"datarvxwlfmbb\"}},\"name\":\"fktmdlf\",\"type\":\"jucpt\",\"etag\":\"esdfujfpn\",\"id\":\"zablqmsybvjf\"}";
+ = "{\"properties\":{\"type\":\"Credential\",\"description\":\"uehcrywwfns\",\"annotations\":[\"datajadnwafjiba\",\"datal\",\"datatdije\"],\"\":{\"oxjwlhulvyz\":\"datarrm\",\"adkvld\":\"datavidokvzq\",\"tpwrm\":\"datacxvoltjyzolnqkdt\"}},\"name\":\"aoeghsqplnyp\",\"type\":\"wcevpmtpq\",\"etag\":\"pgsoje\",\"id\":\"jnlvcgar\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -35,16 +35,16 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
CredentialResource response = manager.credentialOperations()
- .define("z")
- .withExistingFactory("gunnjwmdtb", "qtomcbaiamtdfpkf")
- .withProperties(new Credential().withDescription("elxd")
- .withAnnotations(Arrays.asList("datafsteouzoglvtz", "datajlejvlf", "datazrqkgibpeh", "databctz"))
+ .define("oiqtvfruyinavbf")
+ .withExistingFactory("sdewnkzwyr", "bhh")
+ .withProperties(new Credential().withDescription("vvrzdbrpdveyx")
+ .withAnnotations(Arrays.asList("datauldtfxedmm", "dataz", "datazhvjfij"))
.withAdditionalProperties(mapOf("type", "Credential")))
- .withIfMatch("par")
+ .withIfMatch("hfsoiihjkiajo")
.create();
- Assertions.assertEquals("zablqmsybvjf", response.id());
- Assertions.assertEquals("rgwmge", response.properties().description());
+ Assertions.assertEquals("jnlvcgar", response.id());
+ Assertions.assertEquals("uehcrywwfns", response.properties().description());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsDeleteWithResponseMockTests.java
index 813414e6563a..dd3646648803 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsDeleteWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.credentialOperations()
- .deleteWithResponse("fjsseem", "dfmlail", "xausivh", com.azure.core.util.Context.NONE);
+ .deleteWithResponse("lnjhoemlwea", "sxmshaugenpippt", "reput", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsGetWithResponseMockTests.java
index ccc6b3ca054b..ef278300170c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class CredentialOperationsGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"Credential\",\"description\":\"dlcstucswhmns\",\"annotations\":[\"datahmatfgoerjmhtxip\",\"datavwzbkgt\"],\"\":{\"zeu\":\"datarzmkte\",\"l\":\"dataxt\",\"gpcccg\":\"datajcwlfzxxpwexck\"}},\"name\":\"knjjskzuh\",\"type\":\"yavfeyybyduy\",\"etag\":\"ty\",\"id\":\"miy\"}";
+ = "{\"properties\":{\"type\":\"Credential\",\"description\":\"xrljlqdpqkcbf\",\"annotations\":[\"dataddfre\"],\"\":{\"rphdakwwiezeut\":\"datarsufvtmseuqguz\",\"awmoxvqlwzatv\":\"datar\",\"shvozhhzlmwvce\":\"dataejlocmqladlpqlwt\"}},\"name\":\"vafcjek\",\"type\":\"g\",\"etag\":\"rifyrap\",\"id\":\"iaeqcg\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,10 +31,10 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
CredentialResource response = manager.credentialOperations()
- .getWithResponse("ayjeh", "vowvqpncif", "xtib", "qrhz", com.azure.core.util.Context.NONE)
+ .getWithResponse("izoamttxyddkvi", "l", "bnycgzlicytfpy", "pedno", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("miy", response.id());
- Assertions.assertEquals("dlcstucswhmns", response.properties().description());
+ Assertions.assertEquals("iaeqcg", response.id());
+ Assertions.assertEquals("xrljlqdpqkcbf", response.properties().description());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsListByFactoryMockTests.java
index 2111e86ee53c..7821f1dd9637 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CredentialOperationsListByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class CredentialOperationsListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"type\":\"Credential\",\"description\":\"qfzvvtifcqsuem\",\"annotations\":[\"datautovbpnrfu\"],\"\":{\"psdpfwjcw\":\"datamhmzc\",\"ajtbmjokttqgo\":\"databunfymbwinu\"}},\"name\":\"ajuylkfl\",\"type\":\"ofjskndwywbptvym\",\"etag\":\"pdcddbeozhprlxxb\",\"id\":\"z\"}]}";
+ = "{\"value\":[{\"properties\":{\"type\":\"Credential\",\"description\":\"phieqgo\",\"annotations\":[\"dataxhottykfkwzk\"],\"\":{\"versu\":\"datag\",\"gzcwrhhgnmjxxov\":\"dataveknwldqj\"}},\"name\":\"wnggyv\",\"type\":\"g\",\"etag\":\"papzb\",\"id\":\"fuac\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,10 +31,10 @@ public void testListByFactory() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- PagedIterable response = manager.credentialOperations()
- .listByFactory("wugpnses", "wkhkcdtofakm", com.azure.core.util.Context.NONE);
+ PagedIterable response
+ = manager.credentialOperations().listByFactory("n", "nts", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("z", response.iterator().next().id());
- Assertions.assertEquals("qfzvvtifcqsuem", response.iterator().next().properties().description());
+ Assertions.assertEquals("fuac", response.iterator().next().id());
+ Assertions.assertEquals("phieqgo", response.iterator().next().properties().description());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityReferenceObjectTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityReferenceObjectTests.java
index 50ca97bba8ba..c1f4a5767d10 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityReferenceObjectTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityReferenceObjectTests.java
@@ -17,34 +17,34 @@ public final class CustomActivityReferenceObjectTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CustomActivityReferenceObject model = BinaryData.fromString(
- "{\"linkedServices\":[{\"referenceName\":\"uttlmfc\",\"parameters\":{\"okdqkfbpf\":\"datagaiypihqmmm\"}},{\"referenceName\":\"xnivvuwrvghlzr\",\"parameters\":{\"pbddhfkjsqqqun\":\"datapipwtrtrbf\",\"uyhvaovoqonqjlpc\":\"dataawzkefz\",\"tyz\":\"datayqiytrhhmld\"}}],\"datasets\":[{\"referenceName\":\"st\",\"parameters\":{\"mcprg\":\"datafgzovbbcsbcfe\",\"gvxhw\":\"datachfssbqwvr\",\"mfbl\":\"dataqipfrrvngill\",\"mdffoibx\":\"datagekouxurlifc\"}},{\"referenceName\":\"gcuppwsgawq\",\"parameters\":{\"qbt\":\"datanjz\"}},{\"referenceName\":\"ft\",\"parameters\":{\"ga\":\"datazhox\",\"vtefevhedfzxs\":\"datanouh\"}},{\"referenceName\":\"ypara\",\"parameters\":{\"iqgqvprl\":\"datasfnjokrf\",\"xdxnmuosoziqcui\":\"datasglqiuqsqzu\",\"tgeejxwbredxmd\":\"datakuyaxpuk\",\"oaejylqgenbe\":\"datafxlkwy\"}}]}")
+ "{\"linkedServices\":[{\"referenceName\":\"ylfdryes\",\"parameters\":{\"ybvgemkz\":\"datasparbjsv\",\"czctwacbnhk\":\"dataolvnosb\",\"fh\":\"datadcvjhykptcijuntm\"}},{\"referenceName\":\"ccqhtlqrfsrfxr\",\"parameters\":{\"vzadybhydlqf\":\"dataymtcwac\",\"aesp\":\"dataidastuihn\",\"haoviwuttlmfcn\":\"datawgpjri\"}}],\"datasets\":[{\"referenceName\":\"aiypihqmmmbokdqk\",\"parameters\":{\"l\":\"datafzxnivvuwrvg\",\"bfi\":\"datarlkgpipwtrt\"}},{\"referenceName\":\"bddhfkjsqqqu\",\"parameters\":{\"hvaovoqonqjl\":\"datawzkefzdu\",\"yqiytrhhmld\":\"datac\"}},{\"referenceName\":\"tyz\",\"parameters\":{\"lkfg\":\"datast\",\"fe\":\"dataovbbcsb\",\"chfssbqwvr\":\"datamcprg\",\"qipfrrvngill\":\"datagvxhw\"}}]}")
.toObject(CustomActivityReferenceObject.class);
- Assertions.assertEquals("uttlmfc", model.linkedServices().get(0).referenceName());
- Assertions.assertEquals("st", model.datasets().get(0).referenceName());
+ Assertions.assertEquals("ylfdryes", model.linkedServices().get(0).referenceName());
+ Assertions.assertEquals("aiypihqmmmbokdqk", model.datasets().get(0).referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CustomActivityReferenceObject model = new CustomActivityReferenceObject()
- .withLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("uttlmfc")
- .withParameters(mapOf("okdqkfbpf", "datagaiypihqmmm")),
- new LinkedServiceReference().withReferenceName("xnivvuwrvghlzr")
- .withParameters(mapOf("pbddhfkjsqqqun", "datapipwtrtrbf", "uyhvaovoqonqjlpc", "dataawzkefz", "tyz",
- "datayqiytrhhmld"))))
- .withDatasets(Arrays.asList(
- new DatasetReference().withReferenceName("st")
- .withParameters(mapOf("mcprg", "datafgzovbbcsbcfe", "gvxhw", "datachfssbqwvr", "mfbl",
- "dataqipfrrvngill", "mdffoibx", "datagekouxurlifc")),
- new DatasetReference().withReferenceName("gcuppwsgawq").withParameters(mapOf("qbt", "datanjz")),
- new DatasetReference().withReferenceName("ft")
- .withParameters(mapOf("ga", "datazhox", "vtefevhedfzxs", "datanouh")),
- new DatasetReference().withReferenceName("ypara")
- .withParameters(mapOf("iqgqvprl", "datasfnjokrf", "xdxnmuosoziqcui", "datasglqiuqsqzu",
- "tgeejxwbredxmd", "datakuyaxpuk", "oaejylqgenbe", "datafxlkwy"))));
+ CustomActivityReferenceObject model
+ = new CustomActivityReferenceObject()
+ .withLinkedServices(Arrays.asList(
+ new LinkedServiceReference().withReferenceName("ylfdryes")
+ .withParameters(mapOf("ybvgemkz", "datasparbjsv", "czctwacbnhk", "dataolvnosb", "fh",
+ "datadcvjhykptcijuntm")),
+ new LinkedServiceReference().withReferenceName("ccqhtlqrfsrfxr")
+ .withParameters(mapOf("vzadybhydlqf", "dataymtcwac", "aesp", "dataidastuihn", "haoviwuttlmfcn",
+ "datawgpjri"))))
+ .withDatasets(Arrays.asList(
+ new DatasetReference().withReferenceName("aiypihqmmmbokdqk")
+ .withParameters(mapOf("l", "datafzxnivvuwrvg", "bfi", "datarlkgpipwtrt")),
+ new DatasetReference().withReferenceName("bddhfkjsqqqu")
+ .withParameters(mapOf("hvaovoqonqjl", "datawzkefzdu", "yqiytrhhmld", "datac")),
+ new DatasetReference().withReferenceName("tyz")
+ .withParameters(mapOf("lkfg", "datast", "fe", "dataovbbcsb", "chfssbqwvr", "datamcprg",
+ "qipfrrvngill", "datagvxhw"))));
model = BinaryData.fromObject(model).toObject(CustomActivityReferenceObject.class);
- Assertions.assertEquals("uttlmfc", model.linkedServices().get(0).referenceName());
- Assertions.assertEquals("st", model.datasets().get(0).referenceName());
+ Assertions.assertEquals("ylfdryes", model.linkedServices().get(0).referenceName());
+ Assertions.assertEquals("aiypihqmmmbokdqk", model.datasets().get(0).referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTests.java
index 006bed3d38a8..e75b133b0202 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTests.java
@@ -24,94 +24,78 @@ public final class CustomActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CustomActivity model = BinaryData.fromString(
- "{\"type\":\"Custom\",\"typeProperties\":{\"command\":\"datazqg\",\"resourceLinkedService\":{\"referenceName\":\"arbvblatvbjkq\",\"parameters\":{\"fej\":\"datadgi\",\"ifujynfjwktiyhiy\":\"dataipe\",\"pdafuft\":\"dataatvaodif\"}},\"folderPath\":\"datapsjrqhgnr\",\"referenceObjects\":{\"linkedServices\":[{\"referenceName\":\"wtrxpwuxy\",\"parameters\":{\"oakutdth\":\"datamvshgbjukaswg\",\"tjsebcuynqdl\":\"dataoafhhiyk\",\"vqu\":\"dataptefdvjgbemrjb\"}},{\"referenceName\":\"pdprjethyhbnoye\",\"parameters\":{\"giqoib\":\"datavdrzxobtek\"}},{\"referenceName\":\"aumoguzx\",\"parameters\":{\"tpgkybdktyvr\":\"datarj\",\"psc\":\"datamrqbeqzhnpx\",\"dn\":\"datanygajqmpfrgouwef\",\"akdyqxjpzykkw\":\"datagathvlwhr\"}}],\"datasets\":[{\"referenceName\":\"kpby\",\"parameters\":{\"bsdg\":\"datawi\"}},{\"referenceName\":\"he\",\"parameters\":{\"urthmbgavw\":\"datarbojzfsznephb\",\"mi\":\"dataqjetoaijayvu\"}},{\"referenceName\":\"fnqjcx\",\"parameters\":{\"noxjbhltxtpgqqin\":\"dataeqwxivjhmld\",\"cwawblkkc\":\"dataktayafg\",\"ncqqhbjmvbe\":\"dataixsgklxgsqhczok\",\"ejnwwqyyfctfs\":\"datanlukeqzcbqv\"}}]},\"extendedProperties\":{\"rybbhktnuzor\":\"datarugh\",\"izjqpdfsaut\":\"dataa\"},\"retentionTimeInDays\":\"datatisl\",\"autoUserSpecification\":\"dataxs\"},\"linkedServiceName\":{\"referenceName\":\"diqemcghorrj\",\"parameters\":{\"cfnzpybrflqv\":\"dataczbbvrmvhtmzwgi\"}},\"policy\":{\"timeout\":\"dataqwpmmm\",\"retry\":\"datap\",\"retryIntervalInSeconds\":910562634,\"secureInput\":true,\"secureOutput\":false,\"\":{\"gfqgefxypxmkexjo\":\"databgboqnciiiwuufo\",\"jdaxezfdsoglji\":\"dataa\",\"aifwogqwdxtpmfa\":\"datawduwn\",\"znnkmms\":\"datahk\"}},\"name\":\"nigjoxhzcmgmcsj\",\"description\":\"bu\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"fvbayqwj\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Completed\",\"Failed\"],\"\":{\"uupbihuinjy\":\"datakxl\",\"ejryvvu\":\"datanqwep\"}},{\"activity\":\"tcnxtpamwjbm\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Skipped\",\"Skipped\"],\"\":{\"ycknq\":\"datajutvovhuifblyv\"}},{\"activity\":\"bvssjby\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Succeeded\"],\"\":{\"u\":\"datannqifuhsjz\",\"upfndafrziwjcy\":\"datamplt\",\"vd\":\"datazaneave\"}}],\"userProperties\":[{\"name\":\"hworhzes\",\"value\":\"datadvmxu\"},{\"name\":\"rqpawwjvdohz\",\"value\":\"datawu\"},{\"name\":\"lae\",\"value\":\"datahftlsfwpvflm\"},{\"name\":\"jdu\",\"value\":\"datatxbrj\"}],\"\":{\"uqwdmny\":\"datay\",\"ornzpr\":\"datafvxfsshocxd\"}}")
+ "{\"type\":\"Custom\",\"typeProperties\":{\"command\":\"datagathvlwhr\",\"resourceLinkedService\":{\"referenceName\":\"kdyqxjpzykk\",\"parameters\":{\"sdg\":\"datakkpbybhqwil\",\"kir\":\"datahe\",\"rth\":\"dataojzfsznephbc\",\"ijayvuymib\":\"databgavwbqjeto\"}},\"folderPath\":\"dataqjcxp\",\"referenceObjects\":{\"linkedServices\":[{\"referenceName\":\"wxivj\",\"parameters\":{\"ink\":\"datadvnoxjbhltxtpgq\"}},{\"referenceName\":\"tayafg\",\"parameters\":{\"xgsqhczokunc\":\"dataawblkkccixsgk\",\"qzcbqvjejnwwqyy\":\"dataqhbjmvbeznluk\"}}],\"datasets\":[{\"referenceName\":\"fsdhmrughm\",\"parameters\":{\"pd\":\"databhktnuzorxatizj\",\"lcfxsgjdiqemcgh\":\"datasautviti\",\"bvrmvhtmzwgir\":\"datarrjawfcz\",\"lqvtv\":\"datafnzpybr\"}}]},\"extendedProperties\":{\"p\":\"datapmmmh\",\"iiiwu\":\"dataxthpsugebgboqn\"},\"retentionTimeInDays\":\"dataofgfqge\",\"autoUserSpecification\":\"dataypxm\"},\"linkedServiceName\":{\"referenceName\":\"xjonasjdaxezf\",\"parameters\":{\"ogqw\":\"datagljihwduwncaif\",\"fachkzzn\":\"dataxtp\"}},\"policy\":{\"timeout\":\"datamsfnigjoxhz\",\"retry\":\"datagmcsjyfbut\",\"retryIntervalInSeconds\":1000793246,\"secureInput\":false,\"secureOutput\":false,\"\":{\"jloehhhkxlquupb\":\"dataayqwj\"}},\"name\":\"huinjymnq\",\"description\":\"ptejryvvu\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"amwjb\",\"dependencyConditions\":[\"Completed\",\"Failed\"],\"\":{\"ifblyvqycknqmb\":\"datayxjjutvovh\",\"i\":\"datassjbyneusnncnn\",\"wupfndafrz\":\"datauhsjzduumpl\"}}],\"userProperties\":[{\"name\":\"cy\",\"value\":\"datazaneave\"},{\"name\":\"vd\",\"value\":\"dataulhworhzesqdvm\"}],\"\":{\"wu\":\"datarqpawwjvdohz\",\"hftlsfwpvflm\":\"datalae\"}}")
.toObject(CustomActivity.class);
- Assertions.assertEquals("nigjoxhzcmgmcsj", model.name());
- Assertions.assertEquals("bu", model.description());
+ Assertions.assertEquals("huinjymnq", model.name());
+ Assertions.assertEquals("ptejryvvu", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("fvbayqwj", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("hworhzes", model.userProperties().get(0).name());
- Assertions.assertEquals("diqemcghorrj", model.linkedServiceName().referenceName());
- Assertions.assertEquals(910562634, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("amwjb", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("cy", model.userProperties().get(0).name());
+ Assertions.assertEquals("xjonasjdaxezf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1000793246, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("arbvblatvbjkq", model.resourceLinkedService().referenceName());
- Assertions.assertEquals("wtrxpwuxy", model.referenceObjects().linkedServices().get(0).referenceName());
- Assertions.assertEquals("kpby", model.referenceObjects().datasets().get(0).referenceName());
+ Assertions.assertEquals("kdyqxjpzykk", model.resourceLinkedService().referenceName());
+ Assertions.assertEquals("wxivj", model.referenceObjects().linkedServices().get(0).referenceName());
+ Assertions.assertEquals("fsdhmrughm", model.referenceObjects().datasets().get(0).referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CustomActivity model = new CustomActivity().withName("nigjoxhzcmgmcsj")
- .withDescription("bu")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("fvbayqwj")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("tcnxtpamwjbm")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
- DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("bvssjby")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
- DependencyCondition.SUCCEEDED))
+ CustomActivity model
+ = new CustomActivity().withName("huinjymnq")
+ .withDescription("ptejryvvu")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("amwjb")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("hworhzes").withValue("datadvmxu"),
- new UserProperty().withName("rqpawwjvdohz").withValue("datawu"),
- new UserProperty().withName("lae").withValue("datahftlsfwpvflm"),
- new UserProperty().withName("jdu").withValue("datatxbrj")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("diqemcghorrj")
- .withParameters(mapOf("cfnzpybrflqv", "dataczbbvrmvhtmzwgi")))
- .withPolicy(new ActivityPolicy().withTimeout("dataqwpmmm")
- .withRetry("datap")
- .withRetryIntervalInSeconds(910562634)
- .withSecureInput(true)
- .withSecureOutput(false)
- .withAdditionalProperties(mapOf()))
- .withCommand("datazqg")
- .withResourceLinkedService(new LinkedServiceReference().withReferenceName("arbvblatvbjkq")
- .withParameters(mapOf("fej", "datadgi", "ifujynfjwktiyhiy", "dataipe", "pdafuft", "dataatvaodif")))
- .withFolderPath("datapsjrqhgnr")
- .withReferenceObjects(new CustomActivityReferenceObject()
- .withLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("wtrxpwuxy")
- .withParameters(mapOf("oakutdth", "datamvshgbjukaswg", "tjsebcuynqdl", "dataoafhhiyk", "vqu",
- "dataptefdvjgbemrjb")),
- new LinkedServiceReference().withReferenceName("pdprjethyhbnoye")
- .withParameters(mapOf("giqoib", "datavdrzxobtek")),
- new LinkedServiceReference().withReferenceName("aumoguzx")
- .withParameters(mapOf("tpgkybdktyvr", "datarj", "psc", "datamrqbeqzhnpx", "dn",
- "datanygajqmpfrgouwef", "akdyqxjpzykkw", "datagathvlwhr"))))
- .withDatasets(Arrays.asList(
- new DatasetReference().withReferenceName("kpby").withParameters(mapOf("bsdg", "datawi")),
- new DatasetReference().withReferenceName("he")
- .withParameters(mapOf("urthmbgavw", "datarbojzfsznephb", "mi", "dataqjetoaijayvu")),
- new DatasetReference().withReferenceName("fnqjcx")
- .withParameters(mapOf("noxjbhltxtpgqqin", "dataeqwxivjhmld", "cwawblkkc", "dataktayafg",
- "ncqqhbjmvbe", "dataixsgklxgsqhczok", "ejnwwqyyfctfs", "datanlukeqzcbqv")))))
- .withExtendedProperties(mapOf("rybbhktnuzor", "datarugh", "izjqpdfsaut", "dataa"))
- .withRetentionTimeInDays("datatisl")
- .withAutoUserSpecification("dataxs");
+ .withUserProperties(Arrays.asList(new UserProperty().withName("cy").withValue("datazaneave"),
+ new UserProperty().withName("vd").withValue("dataulhworhzesqdvm")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xjonasjdaxezf")
+ .withParameters(mapOf("ogqw", "datagljihwduwncaif", "fachkzzn", "dataxtp")))
+ .withPolicy(new ActivityPolicy().withTimeout("datamsfnigjoxhz")
+ .withRetry("datagmcsjyfbut")
+ .withRetryIntervalInSeconds(1000793246)
+ .withSecureInput(false)
+ .withSecureOutput(false)
+ .withAdditionalProperties(mapOf()))
+ .withCommand("datagathvlwhr")
+ .withResourceLinkedService(new LinkedServiceReference().withReferenceName("kdyqxjpzykk")
+ .withParameters(mapOf("sdg", "datakkpbybhqwil", "kir", "datahe", "rth", "dataojzfsznephbc",
+ "ijayvuymib", "databgavwbqjeto")))
+ .withFolderPath("dataqjcxp")
+ .withReferenceObjects(
+ new CustomActivityReferenceObject()
+ .withLinkedServices(Arrays.asList(
+ new LinkedServiceReference().withReferenceName("wxivj")
+ .withParameters(mapOf("ink", "datadvnoxjbhltxtpgq")),
+ new LinkedServiceReference().withReferenceName("tayafg")
+ .withParameters(mapOf("xgsqhczokunc", "dataawblkkccixsgk", "qzcbqvjejnwwqyy",
+ "dataqhbjmvbeznluk"))))
+ .withDatasets(Arrays.asList(new DatasetReference().withReferenceName("fsdhmrughm")
+ .withParameters(mapOf("pd", "databhktnuzorxatizj", "lcfxsgjdiqemcgh", "datasautviti",
+ "bvrmvhtmzwgir", "datarrjawfcz", "lqvtv", "datafnzpybr")))))
+ .withExtendedProperties(mapOf("p", "datapmmmh", "iiiwu", "dataxthpsugebgboqn"))
+ .withRetentionTimeInDays("dataofgfqge")
+ .withAutoUserSpecification("dataypxm");
model = BinaryData.fromObject(model).toObject(CustomActivity.class);
- Assertions.assertEquals("nigjoxhzcmgmcsj", model.name());
- Assertions.assertEquals("bu", model.description());
+ Assertions.assertEquals("huinjymnq", model.name());
+ Assertions.assertEquals("ptejryvvu", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("fvbayqwj", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("hworhzes", model.userProperties().get(0).name());
- Assertions.assertEquals("diqemcghorrj", model.linkedServiceName().referenceName());
- Assertions.assertEquals(910562634, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("amwjb", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("cy", model.userProperties().get(0).name());
+ Assertions.assertEquals("xjonasjdaxezf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1000793246, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("arbvblatvbjkq", model.resourceLinkedService().referenceName());
- Assertions.assertEquals("wtrxpwuxy", model.referenceObjects().linkedServices().get(0).referenceName());
- Assertions.assertEquals("kpby", model.referenceObjects().datasets().get(0).referenceName());
+ Assertions.assertEquals("kdyqxjpzykk", model.resourceLinkedService().referenceName());
+ Assertions.assertEquals("wxivj", model.referenceObjects().linkedServices().get(0).referenceName());
+ Assertions.assertEquals("fsdhmrughm", model.referenceObjects().datasets().get(0).referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTypePropertiesTests.java
index 3fa0b7425aff..2dd77391420b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomActivityTypePropertiesTests.java
@@ -18,45 +18,40 @@ public final class CustomActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CustomActivityTypeProperties model = BinaryData.fromString(
- "{\"command\":\"datagmmgtqgzdfjfnree\",\"resourceLinkedService\":{\"referenceName\":\"bumyu\",\"parameters\":{\"rikdfacf\":\"datazfotfoif\",\"fxbqdrjuni\":\"datakbgohxbjizf\"}},\"folderPath\":\"datanhnnghgazdbve\",\"referenceObjects\":{\"linkedServices\":[{\"referenceName\":\"ti\",\"parameters\":{\"pydjdpapndmv\":\"datawrncwhlxvngj\",\"vvtapwkwkthm\":\"databd\",\"npjzx\":\"dataxidecdehskmfiu\"}},{\"referenceName\":\"htsgyyrgdguvkg\",\"parameters\":{\"kznffqv\":\"datag\",\"rwgdpf\":\"dataxnytihhqancw\",\"tkrsn\":\"datady\"}}],\"datasets\":[{\"referenceName\":\"amyolvgkslaiuon\",\"parameters\":{\"wzduhixomxvb\":\"datawvwzuetqcxoamxu\",\"xipgfkcodou\":\"datauzxsn\",\"l\":\"dataeozgnwmcizclnqe\"}},{\"referenceName\":\"pwp\",\"parameters\":{\"spslcvpqwrsf\":\"datajsjkondrkncfoq\",\"xsggaegrppwo\":\"datapi\"}},{\"referenceName\":\"ig\",\"parameters\":{\"yjzokvy\":\"datatophcwzdw\",\"prnqjxsexzxbiwn\":\"datainmywjcfkmfoztwm\",\"ylfdryes\":\"dataewqtbztogih\"}},{\"referenceName\":\"alsparbjs\",\"parameters\":{\"lvnosblc\":\"databvgemkze\",\"nhkp\":\"datactwac\"}}]},\"extendedProperties\":{\"untm\":\"datajhykptci\",\"ccqhtlqrfsrfxr\":\"datafh\",\"dybhydlq\":\"dataxxymtcwacavz\",\"st\":\"dataxid\"},\"retentionTimeInDays\":\"datahnsaespzwgpjri\",\"autoUserSpecification\":\"dataao\"}")
+ "{\"command\":\"datajdu\",\"resourceLinkedService\":{\"referenceName\":\"xbrjdpeypuqwd\",\"parameters\":{\"xdeo\":\"datamfvxfssho\",\"fnreempbumyuiquz\":\"datanzprdgmmgtqgzdf\",\"facflkbgohxbj\":\"dataotfoifjrik\"}},\"folderPath\":\"datafpfxbqdrjunigx\",\"referenceObjects\":{\"linkedServices\":[{\"referenceName\":\"ghga\",\"parameters\":{\"wrncwhlxvngj\":\"datavenvrltijq\",\"bd\":\"datapydjdpapndmv\",\"xidecdehskmfiu\":\"datavvtapwkwkthm\"}},{\"referenceName\":\"npjzx\",\"parameters\":{\"kznffqv\":\"datasgyyrgdguvkgqllg\"}},{\"referenceName\":\"xnytihhqancw\",\"parameters\":{\"snbdfamyolvgksla\":\"datagdpfzdygtk\",\"rswvwzu\":\"datauon\",\"omxvbruzxsnz\":\"datatqcxoamxumwzduhi\"}}],\"datasets\":[{\"referenceName\":\"gf\",\"parameters\":{\"zclnqexlnpwpw\":\"datadouneozgnwmc\"}}]},\"extendedProperties\":{\"cfoqdspslcvpqwrs\":\"datasjkondrk\",\"g\":\"datadpikx\",\"phcwzdwvyjz\":\"dataaegrppwoligfljt\",\"mfoztwmvprn\":\"datakvycinmywjcf\"},\"retentionTimeInDays\":\"dataxsexzxbiwnqe\",\"autoUserSpecification\":\"datatbztog\"}")
.toObject(CustomActivityTypeProperties.class);
- Assertions.assertEquals("bumyu", model.resourceLinkedService().referenceName());
- Assertions.assertEquals("ti", model.referenceObjects().linkedServices().get(0).referenceName());
- Assertions.assertEquals("amyolvgkslaiuon", model.referenceObjects().datasets().get(0).referenceName());
+ Assertions.assertEquals("xbrjdpeypuqwd", model.resourceLinkedService().referenceName());
+ Assertions.assertEquals("ghga", model.referenceObjects().linkedServices().get(0).referenceName());
+ Assertions.assertEquals("gf", model.referenceObjects().datasets().get(0).referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CustomActivityTypeProperties model = new CustomActivityTypeProperties().withCommand("datagmmgtqgzdfjfnree")
- .withResourceLinkedService(new LinkedServiceReference().withReferenceName("bumyu")
- .withParameters(mapOf("rikdfacf", "datazfotfoif", "fxbqdrjuni", "datakbgohxbjizf")))
- .withFolderPath("datanhnnghgazdbve")
+ CustomActivityTypeProperties model = new CustomActivityTypeProperties().withCommand("datajdu")
+ .withResourceLinkedService(new LinkedServiceReference().withReferenceName("xbrjdpeypuqwd")
+ .withParameters(mapOf("xdeo", "datamfvxfssho", "fnreempbumyuiquz", "datanzprdgmmgtqgzdf",
+ "facflkbgohxbj", "dataotfoifjrik")))
+ .withFolderPath("datafpfxbqdrjunigx")
.withReferenceObjects(new CustomActivityReferenceObject()
.withLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("ti")
- .withParameters(mapOf("pydjdpapndmv", "datawrncwhlxvngj", "vvtapwkwkthm", "databd", "npjzx",
- "dataxidecdehskmfiu")),
- new LinkedServiceReference().withReferenceName("htsgyyrgdguvkg")
- .withParameters(mapOf("kznffqv", "datag", "rwgdpf", "dataxnytihhqancw", "tkrsn", "datady"))))
- .withDatasets(Arrays.asList(
- new DatasetReference().withReferenceName("amyolvgkslaiuon")
- .withParameters(mapOf("wzduhixomxvb", "datawvwzuetqcxoamxu", "xipgfkcodou", "datauzxsn", "l",
- "dataeozgnwmcizclnqe")),
- new DatasetReference().withReferenceName("pwp")
- .withParameters(mapOf("spslcvpqwrsf", "datajsjkondrkncfoq", "xsggaegrppwo", "datapi")),
- new DatasetReference().withReferenceName("ig")
- .withParameters(mapOf("yjzokvy", "datatophcwzdw", "prnqjxsexzxbiwn", "datainmywjcfkmfoztwm",
- "ylfdryes", "dataewqtbztogih")),
- new DatasetReference().withReferenceName("alsparbjs")
- .withParameters(mapOf("lvnosblc", "databvgemkze", "nhkp", "datactwac")))))
- .withExtendedProperties(mapOf("untm", "datajhykptci", "ccqhtlqrfsrfxr", "datafh", "dybhydlq",
- "dataxxymtcwacavz", "st", "dataxid"))
- .withRetentionTimeInDays("datahnsaespzwgpjri")
- .withAutoUserSpecification("dataao");
+ new LinkedServiceReference().withReferenceName("ghga")
+ .withParameters(mapOf("wrncwhlxvngj", "datavenvrltijq", "bd", "datapydjdpapndmv",
+ "xidecdehskmfiu", "datavvtapwkwkthm")),
+ new LinkedServiceReference().withReferenceName("npjzx")
+ .withParameters(mapOf("kznffqv", "datasgyyrgdguvkgqllg")),
+ new LinkedServiceReference().withReferenceName("xnytihhqancw")
+ .withParameters(mapOf("snbdfamyolvgksla", "datagdpfzdygtk", "rswvwzu", "datauon",
+ "omxvbruzxsnz", "datatqcxoamxumwzduhi"))))
+ .withDatasets(Arrays.asList(new DatasetReference().withReferenceName("gf")
+ .withParameters(mapOf("zclnqexlnpwpw", "datadouneozgnwmc")))))
+ .withExtendedProperties(mapOf("cfoqdspslcvpqwrs", "datasjkondrk", "g", "datadpikx", "phcwzdwvyjz",
+ "dataaegrppwoligfljt", "mfoztwmvprn", "datakvycinmywjcf"))
+ .withRetentionTimeInDays("dataxsexzxbiwnqe")
+ .withAutoUserSpecification("datatbztog");
model = BinaryData.fromObject(model).toObject(CustomActivityTypeProperties.class);
- Assertions.assertEquals("bumyu", model.resourceLinkedService().referenceName());
- Assertions.assertEquals("ti", model.referenceObjects().linkedServices().get(0).referenceName());
- Assertions.assertEquals("amyolvgkslaiuon", model.referenceObjects().datasets().get(0).referenceName());
+ Assertions.assertEquals("xbrjdpeypuqwd", model.resourceLinkedService().referenceName());
+ Assertions.assertEquals("ghga", model.referenceObjects().linkedServices().get(0).referenceName());
+ Assertions.assertEquals("gf", model.referenceObjects().datasets().get(0).referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDataSourceLinkedServiceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDataSourceLinkedServiceTests.java
index 11f49c599156..129d1442cda4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDataSourceLinkedServiceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDataSourceLinkedServiceTests.java
@@ -18,30 +18,32 @@ public final class CustomDataSourceLinkedServiceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CustomDataSourceLinkedService model = BinaryData.fromString(
- "{\"type\":\"CustomDataSource\",\"typeProperties\":\"datacsp\",\"version\":\"rndqymloslqgs\",\"connectVia\":{\"referenceName\":\"nqqzqdvgn\",\"parameters\":{\"wphbuzmvjil\":\"datakgoynyaa\",\"hrjwyxduwimwnuvj\":\"datalbmfkctpai\"}},\"description\":\"wpfxi\",\"parameters\":{\"yjdbc\":{\"type\":\"Array\",\"defaultValue\":\"datanjtksw\"},\"gu\":{\"type\":\"Bool\",\"defaultValue\":\"dataojtmpdkcbpk\"}},\"annotations\":[\"dataitkce\",\"datadwgussctnppxxeys\",\"dataenfwugonysemun\"],\"\":{\"sxuuksvfsukpk\":\"datavnbckl\"}}")
+ "{\"type\":\"CustomDataSource\",\"typeProperties\":\"datajhokhijghpvjq\",\"version\":\"kikdatbwyarqt\",\"connectVia\":{\"referenceName\":\"jblhefq\",\"parameters\":{\"klbjlnbxouc\":\"datanxtpzdgyilwu\",\"oke\":\"dataddplgjfhvia\",\"uosc\":\"datacmadyoctmd\"}},\"description\":\"wbestntoeteu\",\"parameters\":{\"efrfugthcdbzoxh\":{\"type\":\"SecureString\",\"defaultValue\":\"datazftsb\"},\"ijpkbr\":{\"type\":\"Bool\",\"defaultValue\":\"datagpbogpbwefoxlz\"}},\"annotations\":[\"dataup\"],\"\":{\"vgit\":\"dataqeqjtzawen\",\"ohnizvvekpq\":\"datadjixkepla\"}}")
.toObject(CustomDataSourceLinkedService.class);
- Assertions.assertEquals("rndqymloslqgs", model.version());
- Assertions.assertEquals("nqqzqdvgn", model.connectVia().referenceName());
- Assertions.assertEquals("wpfxi", model.description());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("yjdbc").type());
+ Assertions.assertEquals("kikdatbwyarqt", model.version());
+ Assertions.assertEquals("jblhefq", model.connectVia().referenceName());
+ Assertions.assertEquals("wbestntoeteu", model.description());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("efrfugthcdbzoxh").type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CustomDataSourceLinkedService model = new CustomDataSourceLinkedService().withVersion("rndqymloslqgs")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("nqqzqdvgn")
- .withParameters(mapOf("wphbuzmvjil", "datakgoynyaa", "hrjwyxduwimwnuvj", "datalbmfkctpai")))
- .withDescription("wpfxi")
- .withParameters(mapOf("yjdbc",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanjtksw"), "gu",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataojtmpdkcbpk")))
- .withAnnotations(Arrays.asList("dataitkce", "datadwgussctnppxxeys", "dataenfwugonysemun"))
- .withTypeProperties("datacsp");
+ CustomDataSourceLinkedService model = new CustomDataSourceLinkedService().withVersion("kikdatbwyarqt")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("jblhefq")
+ .withParameters(
+ mapOf("klbjlnbxouc", "datanxtpzdgyilwu", "oke", "dataddplgjfhvia", "uosc", "datacmadyoctmd")))
+ .withDescription("wbestntoeteu")
+ .withParameters(mapOf("efrfugthcdbzoxh",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datazftsb"),
+ "ijpkbr",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datagpbogpbwefoxlz")))
+ .withAnnotations(Arrays.asList("dataup"))
+ .withTypeProperties("datajhokhijghpvjq");
model = BinaryData.fromObject(model).toObject(CustomDataSourceLinkedService.class);
- Assertions.assertEquals("rndqymloslqgs", model.version());
- Assertions.assertEquals("nqqzqdvgn", model.connectVia().referenceName());
- Assertions.assertEquals("wpfxi", model.description());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("yjdbc").type());
+ Assertions.assertEquals("kikdatbwyarqt", model.version());
+ Assertions.assertEquals("jblhefq", model.connectVia().referenceName());
+ Assertions.assertEquals("wbestntoeteu", model.description());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("efrfugthcdbzoxh").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDatasetTests.java
index 3171f5e2397c..6c753dce56d0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomDatasetTests.java
@@ -19,34 +19,37 @@ public final class CustomDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CustomDataset model = BinaryData.fromString(
- "{\"type\":\"CustomDataset\",\"typeProperties\":\"dataqmiwxzfvvzucqfg\",\"description\":\"jnbxwbmwdukin\",\"structure\":\"dataxhgdeke\",\"schema\":\"dataouyvew\",\"linkedServiceName\":{\"referenceName\":\"pzrdwc\",\"parameters\":{\"fhhhtestdq\":\"dataohgcand\",\"vfkdxccyijji\":\"datadnnckkpljdsh\",\"duydwnwgru\":\"datahijzrqnjxmvv\",\"dym\":\"datahqld\"}},\"parameters\":{\"jrxgunnq\":{\"type\":\"Float\",\"defaultValue\":\"dataexqwqnghxnimvy\"},\"mg\":{\"type\":\"Array\",\"defaultValue\":\"datauqtnylquevqmvy\"}},\"annotations\":[\"dataebsnz\",\"datawgsqufmjxcyoseqc\",\"datazisvbrqgcyjpgaw\",\"datapkwonrzpghlr\"],\"folder\":{\"name\":\"gblxbu\"},\"\":{\"hvfj\":\"datavjztaflvsmfj\",\"ewfeq\":\"dataqrttjfuqmmf\"}}")
+ "{\"type\":\"CustomDataset\",\"typeProperties\":\"dataxvmdr\",\"description\":\"n\",\"structure\":\"dataovazoymdvhhpl\",\"schema\":\"datawwd\",\"linkedServiceName\":{\"referenceName\":\"atveqm\",\"parameters\":{\"armhpwbuklv\":\"dataswzeyxry\",\"aemcezevftmh\":\"datamfasgtlvhqpoilos\",\"okjyghzt\":\"datal\"}},\"parameters\":{\"vwiftd\":{\"type\":\"Array\",\"defaultValue\":\"datatpcflcezsw\"},\"jnqswxd\":{\"type\":\"Int\",\"defaultValue\":\"databfpfhruptsyq\"},\"clqddnhfknebw\":{\"type\":\"Object\",\"defaultValue\":\"datamxqukrcdio\"}},\"annotations\":[\"datapnyzcwyjs\",\"datakaqldqabnwvpa\",\"databqxfbb\",\"datagcfddofxnfb\"],\"folder\":{\"name\":\"yrqaedwovoc\"},\"\":{\"fmi\":\"datagoeayokr\"}}")
.toObject(CustomDataset.class);
- Assertions.assertEquals("jnbxwbmwdukin", model.description());
- Assertions.assertEquals("pzrdwc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("jrxgunnq").type());
- Assertions.assertEquals("gblxbu", model.folder().name());
+ Assertions.assertEquals("n", model.description());
+ Assertions.assertEquals("atveqm", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("vwiftd").type());
+ Assertions.assertEquals("yrqaedwovoc", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CustomDataset model = new CustomDataset().withDescription("jnbxwbmwdukin")
- .withStructure("dataxhgdeke")
- .withSchema("dataouyvew")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("pzrdwc")
- .withParameters(mapOf("fhhhtestdq", "dataohgcand", "vfkdxccyijji", "datadnnckkpljdsh", "duydwnwgru",
- "datahijzrqnjxmvv", "dym", "datahqld")))
- .withParameters(mapOf("jrxgunnq",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataexqwqnghxnimvy"), "mg",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datauqtnylquevqmvy")))
- .withAnnotations(
- Arrays.asList("dataebsnz", "datawgsqufmjxcyoseqc", "datazisvbrqgcyjpgaw", "datapkwonrzpghlr"))
- .withFolder(new DatasetFolder().withName("gblxbu"))
- .withTypeProperties("dataqmiwxzfvvzucqfg");
+ CustomDataset model
+ = new CustomDataset().withDescription("n")
+ .withStructure("dataovazoymdvhhpl")
+ .withSchema("datawwd")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("atveqm")
+ .withParameters(mapOf("armhpwbuklv", "dataswzeyxry", "aemcezevftmh", "datamfasgtlvhqpoilos",
+ "okjyghzt", "datal")))
+ .withParameters(mapOf("vwiftd",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datatpcflcezsw"),
+ "jnqswxd",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("databfpfhruptsyq"),
+ "clqddnhfknebw",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datamxqukrcdio")))
+ .withAnnotations(Arrays.asList("datapnyzcwyjs", "datakaqldqabnwvpa", "databqxfbb", "datagcfddofxnfb"))
+ .withFolder(new DatasetFolder().withName("yrqaedwovoc"))
+ .withTypeProperties("dataxvmdr");
model = BinaryData.fromObject(model).toObject(CustomDataset.class);
- Assertions.assertEquals("jnbxwbmwdukin", model.description());
- Assertions.assertEquals("pzrdwc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("jrxgunnq").type());
- Assertions.assertEquals("gblxbu", model.folder().name());
+ Assertions.assertEquals("n", model.description());
+ Assertions.assertEquals("atveqm", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("vwiftd").type());
+ Assertions.assertEquals("yrqaedwovoc", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTests.java
index fd7c804d5264..3873986c2022 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTests.java
@@ -17,40 +17,47 @@ public final class CustomEventsTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CustomEventsTrigger model = BinaryData.fromString(
- "{\"type\":\"CustomEventsTrigger\",\"typeProperties\":{\"subjectBeginsWith\":\"zcmwqfdhgpmvlfmv\",\"subjectEndsWith\":\"mjmp\",\"events\":[\"datazxbafscdp\",\"datazporjhubzkzjazf\"],\"scope\":\"y\"},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"tcnyhsdgmoxnelhx\",\"name\":\"fyzb\"},\"parameters\":{\"prgpm\":\"datafcsvipwahehuc\",\"fzcsklvtceaoi\":\"datatjvuhcw\",\"bjfhpaywwesa\":\"dataurqlcdh\"}},{\"pipelineReference\":{\"referenceName\":\"uqpskvxbdlrar\",\"name\":\"iat\"},\"parameters\":{\"nyfjwoaom\":\"dataqsbyyleyopgyyg\"}}],\"description\":\"kpcwffo\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datavgjuzgqkxs\",\"dataavbteaegyojy\"],\"\":{\"hbztlvujbhw\":\"datapcdhqjc\",\"cihkjjjbit\":\"dataszrhf\",\"fwmasodsmjn\":\"datauriizyrgzxpr\"}}")
+ "{\"type\":\"CustomEventsTrigger\",\"typeProperties\":{\"subjectBeginsWith\":\"fimonreukc\",\"subjectEndsWith\":\"sdaipnhpov\",\"events\":[\"datav\",\"datatbybcxgrrlzdn\",\"datacxtqqpfgjny\",\"datauqi\"],\"scope\":\"oiuj\"},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"sfvyv\",\"name\":\"uclqtdcasjnzec\"},\"parameters\":{\"lzicltwan\":\"datapjkczkc\"}},{\"pipelineReference\":{\"referenceName\":\"zycxvifkzs\",\"name\":\"vlqinl\"},\"parameters\":{\"vkwxbb\":\"dataeevzelmmwmdhm\",\"nmnojfmztpwu\":\"datamck\",\"tvyeyeb\":\"datamu\",\"us\":\"datazrfonqjnpkofj\"}},{\"pipelineReference\":{\"referenceName\":\"yuir\",\"name\":\"xrftfamozyv\"},\"parameters\":{\"qtq\":\"datacflp\",\"lgzctfnlakl\":\"datacowmukzcrp\",\"xzwiehqvvbgwxp\":\"datazbeutqfx\",\"kmzubdmcdfvw\":\"datawticu\"}},{\"pipelineReference\":{\"referenceName\":\"z\",\"name\":\"jcxmffaqo\"},\"parameters\":{\"zwwsfrpbwv\":\"dataeywbpenqpz\"}}],\"description\":\"dghmny\",\"runtimeState\":\"Started\",\"annotations\":[\"datanjyulo\"],\"\":{\"xfwlkmj\":\"datalwcx\",\"mx\":\"dataekbmwizish\",\"aotaakcy\":\"datarsnmwiybl\",\"osnbwbcnfo\":\"datas\"}}")
.toObject(CustomEventsTrigger.class);
- Assertions.assertEquals("kpcwffo", model.description());
- Assertions.assertEquals("tcnyhsdgmoxnelhx", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("fyzb", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals("zcmwqfdhgpmvlfmv", model.subjectBeginsWith());
- Assertions.assertEquals("mjmp", model.subjectEndsWith());
- Assertions.assertEquals("y", model.scope());
+ Assertions.assertEquals("dghmny", model.description());
+ Assertions.assertEquals("sfvyv", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("uclqtdcasjnzec", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("fimonreukc", model.subjectBeginsWith());
+ Assertions.assertEquals("sdaipnhpov", model.subjectEndsWith());
+ Assertions.assertEquals("oiuj", model.scope());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- CustomEventsTrigger model = new CustomEventsTrigger().withDescription("kpcwffo")
- .withAnnotations(Arrays.asList("datavgjuzgqkxs", "dataavbteaegyojy"))
+ CustomEventsTrigger model = new CustomEventsTrigger().withDescription("dghmny")
+ .withAnnotations(Arrays.asList("datanjyulo"))
.withPipelines(Arrays.asList(
new TriggerPipelineReference()
.withPipelineReference(
- new PipelineReference().withReferenceName("tcnyhsdgmoxnelhx").withName("fyzb"))
- .withParameters(mapOf("prgpm", "datafcsvipwahehuc", "fzcsklvtceaoi", "datatjvuhcw", "bjfhpaywwesa",
- "dataurqlcdh")),
+ new PipelineReference().withReferenceName("sfvyv").withName("uclqtdcasjnzec"))
+ .withParameters(mapOf("lzicltwan", "datapjkczkc")),
new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("uqpskvxbdlrar").withName("iat"))
- .withParameters(mapOf("nyfjwoaom", "dataqsbyyleyopgyyg"))))
- .withSubjectBeginsWith("zcmwqfdhgpmvlfmv")
- .withSubjectEndsWith("mjmp")
- .withEvents(Arrays.asList("datazxbafscdp", "datazporjhubzkzjazf"))
- .withScope("y");
+ .withPipelineReference(new PipelineReference().withReferenceName("zycxvifkzs").withName("vlqinl"))
+ .withParameters(mapOf("vkwxbb", "dataeevzelmmwmdhm", "nmnojfmztpwu", "datamck", "tvyeyeb", "datamu",
+ "us", "datazrfonqjnpkofj")),
+ new TriggerPipelineReference()
+ .withPipelineReference(new PipelineReference().withReferenceName("yuir").withName("xrftfamozyv"))
+ .withParameters(mapOf("qtq", "datacflp", "lgzctfnlakl", "datacowmukzcrp", "xzwiehqvvbgwxp",
+ "datazbeutqfx", "kmzubdmcdfvw", "datawticu")),
+ new TriggerPipelineReference()
+ .withPipelineReference(new PipelineReference().withReferenceName("z").withName("jcxmffaqo"))
+ .withParameters(mapOf("zwwsfrpbwv", "dataeywbpenqpz"))))
+ .withSubjectBeginsWith("fimonreukc")
+ .withSubjectEndsWith("sdaipnhpov")
+ .withEvents(Arrays.asList("datav", "datatbybcxgrrlzdn", "datacxtqqpfgjny", "datauqi"))
+ .withScope("oiuj");
model = BinaryData.fromObject(model).toObject(CustomEventsTrigger.class);
- Assertions.assertEquals("kpcwffo", model.description());
- Assertions.assertEquals("tcnyhsdgmoxnelhx", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("fyzb", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals("zcmwqfdhgpmvlfmv", model.subjectBeginsWith());
- Assertions.assertEquals("mjmp", model.subjectEndsWith());
- Assertions.assertEquals("y", model.scope());
+ Assertions.assertEquals("dghmny", model.description());
+ Assertions.assertEquals("sfvyv", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("uclqtdcasjnzec", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("fimonreukc", model.subjectBeginsWith());
+ Assertions.assertEquals("sdaipnhpov", model.subjectEndsWith());
+ Assertions.assertEquals("oiuj", model.scope());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTypePropertiesTests.java
index 78f5071a439c..c76a3584f59d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/CustomEventsTriggerTypePropertiesTests.java
@@ -13,23 +13,23 @@ public final class CustomEventsTriggerTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
CustomEventsTriggerTypeProperties model = BinaryData.fromString(
- "{\"subjectBeginsWith\":\"doomhrlgidqxbrdh\",\"subjectEndsWith\":\"cq\",\"events\":[\"dataspj\"],\"scope\":\"ahienkliyf\"}")
+ "{\"subjectBeginsWith\":\"ndbwwnlgaoub\",\"subjectEndsWith\":\"hdccghdzqvwlixhq\",\"events\":[\"dataqsprnhlsfhfjwa\",\"datas\"],\"scope\":\"qytfvjvmjhuvuad\"}")
.toObject(CustomEventsTriggerTypeProperties.class);
- Assertions.assertEquals("doomhrlgidqxbrdh", model.subjectBeginsWith());
- Assertions.assertEquals("cq", model.subjectEndsWith());
- Assertions.assertEquals("ahienkliyf", model.scope());
+ Assertions.assertEquals("ndbwwnlgaoub", model.subjectBeginsWith());
+ Assertions.assertEquals("hdccghdzqvwlixhq", model.subjectEndsWith());
+ Assertions.assertEquals("qytfvjvmjhuvuad", model.scope());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
CustomEventsTriggerTypeProperties model
- = new CustomEventsTriggerTypeProperties().withSubjectBeginsWith("doomhrlgidqxbrdh")
- .withSubjectEndsWith("cq")
- .withEvents(Arrays.asList("dataspj"))
- .withScope("ahienkliyf");
+ = new CustomEventsTriggerTypeProperties().withSubjectBeginsWith("ndbwwnlgaoub")
+ .withSubjectEndsWith("hdccghdzqvwlixhq")
+ .withEvents(Arrays.asList("dataqsprnhlsfhfjwa", "datas"))
+ .withScope("qytfvjvmjhuvuad");
model = BinaryData.fromObject(model).toObject(CustomEventsTriggerTypeProperties.class);
- Assertions.assertEquals("doomhrlgidqxbrdh", model.subjectBeginsWith());
- Assertions.assertEquals("cq", model.subjectEndsWith());
- Assertions.assertEquals("ahienkliyf", model.scope());
+ Assertions.assertEquals("ndbwwnlgaoub", model.subjectBeginsWith());
+ Assertions.assertEquals("hdccghdzqvwlixhq", model.subjectEndsWith());
+ Assertions.assertEquals("qytfvjvmjhuvuad", model.scope());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandDefaultValueTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandDefaultValueTests.java
index a5429dd3198b..50abc0242280 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandDefaultValueTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandDefaultValueTests.java
@@ -11,14 +11,14 @@ public final class DWCopyCommandDefaultValueTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DWCopyCommandDefaultValue model
- = BinaryData.fromString("{\"columnName\":\"datagaw\",\"defaultValue\":\"dataujizdmhepfj\"}")
+ = BinaryData.fromString("{\"columnName\":\"datan\",\"defaultValue\":\"datapnpunrvjb\"}")
.toObject(DWCopyCommandDefaultValue.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DWCopyCommandDefaultValue model
- = new DWCopyCommandDefaultValue().withColumnName("datagaw").withDefaultValue("dataujizdmhepfj");
+ = new DWCopyCommandDefaultValue().withColumnName("datan").withDefaultValue("datapnpunrvjb");
model = BinaryData.fromObject(model).toObject(DWCopyCommandDefaultValue.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandSettingsTests.java
index 52ba7e4580c0..351428709763 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DWCopyCommandSettingsTests.java
@@ -16,23 +16,24 @@ public final class DWCopyCommandSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DWCopyCommandSettings model = BinaryData.fromString(
- "{\"defaultValues\":[{\"columnName\":\"dataxregbssqthcyw\",\"defaultValue\":\"dataqxprsocfxlrzj\"},{\"columnName\":\"dataflizmul\",\"defaultValue\":\"dataaulwlzekygnepj\"},{\"columnName\":\"dataxqdrphiyxjq\",\"defaultValue\":\"datanpztlac\"},{\"columnName\":\"datafzsf\",\"defaultValue\":\"dataa\"}],\"additionalOptions\":{\"hsorca\":\"rwviovv\",\"oigzwedfteratv\":\"kfh\"}}")
+ "{\"defaultValues\":[{\"columnName\":\"dataazuboig\",\"defaultValue\":\"datawpbbjzdvaqoilgkz\"},{\"columnName\":\"datazpvjwego\",\"defaultValue\":\"dataceqyrajdvvs\"},{\"columnName\":\"datatyypercazcchvww\",\"defaultValue\":\"dataazztvotf\"}],\"additionalOptions\":{\"oszcmfmynljigj\":\"yfxkfgxxefzliguw\",\"dmwtiv\":\"nk\"}}")
.toObject(DWCopyCommandSettings.class);
- Assertions.assertEquals("rwviovv", model.additionalOptions().get("hsorca"));
+ Assertions.assertEquals("yfxkfgxxefzliguw", model.additionalOptions().get("oszcmfmynljigj"));
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DWCopyCommandSettings model = new DWCopyCommandSettings()
- .withDefaultValues(Arrays.asList(
- new DWCopyCommandDefaultValue().withColumnName("dataxregbssqthcyw")
- .withDefaultValue("dataqxprsocfxlrzj"),
- new DWCopyCommandDefaultValue().withColumnName("dataflizmul").withDefaultValue("dataaulwlzekygnepj"),
- new DWCopyCommandDefaultValue().withColumnName("dataxqdrphiyxjq").withDefaultValue("datanpztlac"),
- new DWCopyCommandDefaultValue().withColumnName("datafzsf").withDefaultValue("dataa")))
- .withAdditionalOptions(mapOf("hsorca", "rwviovv", "oigzwedfteratv", "kfh"));
+ DWCopyCommandSettings model
+ = new DWCopyCommandSettings()
+ .withDefaultValues(Arrays.asList(
+ new DWCopyCommandDefaultValue().withColumnName("dataazuboig")
+ .withDefaultValue("datawpbbjzdvaqoilgkz"),
+ new DWCopyCommandDefaultValue().withColumnName("datazpvjwego").withDefaultValue("dataceqyrajdvvs"),
+ new DWCopyCommandDefaultValue().withColumnName("datatyypercazcchvww")
+ .withDefaultValue("dataazztvotf")))
+ .withAdditionalOptions(mapOf("oszcmfmynljigj", "yfxkfgxxefzliguw", "dmwtiv", "nk"));
model = BinaryData.fromObject(model).toObject(DWCopyCommandSettings.class);
- Assertions.assertEquals("rwviovv", model.additionalOptions().get("hsorca"));
+ Assertions.assertEquals("yfxkfgxxefzliguw", model.additionalOptions().get("oszcmfmynljigj"));
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsAddDataFlowWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsAddDataFlowWithResponseMockTests.java
index 5405d1c65225..601bdb1bb983 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsAddDataFlowWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsAddDataFlowWithResponseMockTests.java
@@ -39,7 +39,7 @@
public final class DataFlowDebugSessionsAddDataFlowWithResponseMockTests {
@Test
public void testAddDataFlowWithResponse() throws Exception {
- String responseStr = "{\"jobVersion\":\"mgllnyohnhfup\"}";
+ String responseStr = "{\"jobVersion\":\"obpxfgp\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -48,118 +48,90 @@ public void testAddDataFlowWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- AddDataFlowToDebugSessionResponse response
- = manager.dataFlowDebugSessions()
- .addDataFlowWithResponse("ccwievjndvaf", "cvn", new DataFlowDebugPackage().withSessionId("xlcgycv")
- .withDataFlow(new DataFlowDebugResource().withName("utsabuvuuweq")
- .withProperties(new DataFlow().withDescription("cfxz")
- .withAnnotations(Arrays.asList("dataioqtafmbxtn"))
- .withFolder(new DataFlowFolder().withName("y"))))
- .withDataFlows(Arrays.asList(
- new DataFlowDebugResource().withName("sqhkjuqrklxnbbkb")
- .withProperties(new DataFlow().withDescription("netuvsqv")
- .withAnnotations(Arrays
- .asList("dataumdznbl", "dataofdmlrtlhpfucfi", "dataaklflwqdj", "databogtbykskq"))
- .withFolder(new DataFlowFolder().withName("prrixkobmrrnkd"))),
- new DataFlowDebugResource().withName("dctsqxwqsszdwwk")
- .withProperties(new DataFlow().withDescription("n")
- .withAnnotations(Arrays.asList("dataua", "databfxvlacllteuksgu", "datacotgqgevie",
- "datayhowvnzwhypj"))
- .withFolder(new DataFlowFolder().withName("alptjpsbdch"))),
- new DataFlowDebugResource().withName("ddus")
- .withProperties(new DataFlow().withDescription("zmcprtanagehbrh")
- .withAnnotations(Arrays.asList("dataatjsseb", "datadusj", "datailp", "dataccxeg"))
- .withFolder(new DataFlowFolder().withName("tqgcjvklnrzoafx")))))
- .withDatasets(Arrays.asList(
- new DatasetDebugResource().withName("bqodyvvpcoia")
+ AddDataFlowToDebugSessionResponse response = manager.dataFlowDebugSessions()
+ .addDataFlowWithResponse("afdlfkyirjbf", "rqivibzoqgut",
+ new DataFlowDebugPackage().withSessionId("awwmkgzsqr")
+ .withDataFlow(new DataFlowDebugResource().withName("aa")
+ .withProperties(new DataFlow().withDescription("cjmhaarkhlayer")
+ .withAnnotations(Arrays.asList("dataiuwne", "dataebheiywmxsxlmk"))
+ .withFolder(new DataFlowFolder().withName("nngwpgbfrtx"))))
+ .withDataFlows(Arrays.asList(new DataFlowDebugResource().withName("xgxohiw")
+ .withProperties(new DataFlow().withDescription("pmdnigajbxjnr")
+ .withAnnotations(Arrays.asList("dataqpafrwmxmdj", "datazhutcaqqdchmxr", "datahljqhoiqvkzm"))
+ .withFolder(new DataFlowFolder().withName("xzttgva")))))
+ .withDatasets(
+ Arrays.asList(new DatasetDebugResource().withName("gqiybfskxuyosd")
.withProperties(new Dataset()
- .withDescription("hh")
- .withStructure("datalmxzdwpdwbnouk")
- .withSchema("datanyegh")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("fmuxd")
- .withParameters(mapOf("zle", "datagdcszzzedf")))
- .withParameters(mapOf("deqmfzyhikhnw",
- new ParameterSpecification().withType(ParameterType.OBJECT), "ftlj",
- new ParameterSpecification().withType(ParameterType.ARRAY)))
- .withAnnotations(Arrays.asList("datapfk", "dataybe", "dataax", "datathppjxtobeq"))
- .withFolder(new DatasetFolder().withName("adoqijfll"))
- .withAdditionalProperties(mapOf("type", "Dataset"))),
- new DatasetDebugResource().withName("jakezorhjh")
- .withProperties(new Dataset().withDescription("gvaecww")
- .withStructure("datag")
- .withSchema("dataabhfrg")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("p")
- .withParameters(mapOf("krfe", "datah")))
- .withParameters(mapOf("zxvgfxzckqwqujpu",
- new ParameterSpecification().withType(ParameterType.STRING), "sjalhw",
- new ParameterSpecification().withType(ParameterType.INT), "pvpdsvycjuxab",
- new ParameterSpecification()
- .withType(ParameterType.BOOL),
- "phgogmgg", new ParameterSpecification().withType(ParameterType.BOOL)))
- .withAnnotations(Arrays.asList("datacizrst", "datannmjpgzw"))
- .withFolder(new DatasetFolder().withName("pzshgsidkz"))
- .withAdditionalProperties(mapOf("type", "Dataset"))),
- new DatasetDebugResource().withName("pzingxbk")
- .withProperties(new Dataset().withDescription("qh")
- .withStructure("datauldztvum")
- .withSchema("datakrxgaiddgdgkhiqw")
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("wxrcydmkyoojcfsb")
- .withParameters(mapOf("krcmxt", "databnxey", "aqlszlymyq", "datawolzuk")))
+ .withDescription("heukcla")
+ .withStructure("dataipwkxf")
+ .withSchema("dataharsvai")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hme")
+ .withParameters(mapOf("ajtqyevqtydxkpy", "dataakpr", "mlo", "dataxcjafhctqn",
+ "zucuaixvjv", "dataok")))
+ .withParameters(mapOf("mq", new ParameterSpecification().withType(ParameterType.BOOL),
+ "bxexyydibfqrtpip", new ParameterSpecification().withType(ParameterType.FLOAT),
+ "zi", new ParameterSpecification().withType(ParameterType.STRING), "vudvpyba",
+ new ParameterSpecification().withType(ParameterType.OBJECT)))
+ .withAnnotations(Arrays.asList("datalnttgpblnxq", "datagecijrncvjs"))
+ .withFolder(new DatasetFolder().withName("urcxtyfbbomugubc"))
+ .withAdditionalProperties(mapOf("type", "Dataset")))))
+ .withLinkedServices(Arrays.asList(
+ new LinkedServiceDebugResource().withName("qsb")
+ .withProperties(new LinkedService().withVersion("uclq")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("wpgipttpsedtwt")
+ .withParameters(mapOf("utonp", "datahuusr", "ls", "datatazpupkebwses")))
+ .withDescription("wdfoprdytsgypvi")
+ .withParameters(mapOf("qzdoy",
+ new ParameterSpecification().withType(ParameterType.BOOL), "pkjpcgtgnhz",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING), "hwftjn",
+ new ParameterSpecification().withType(ParameterType.FLOAT), "ptqxksi",
+ new ParameterSpecification().withType(ParameterType.FLOAT)))
+ .withAnnotations(Arrays.asList("datafhaj"))
+ .withAdditionalProperties(mapOf("type", "LinkedService"))),
+ new LinkedServiceDebugResource().withName("xzhobtxub")
+ .withProperties(new LinkedService().withVersion("gncke")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("tqaomihrtbksd")
+ .withParameters(mapOf("oxnlvix", "dataxwficz", "xzaolzkoyniragb", "datadsi", "h",
+ "dataiukmkmthioae")))
+ .withDescription("lcen")
.withParameters(
- mapOf("uwqmi", new ParameterSpecification().withType(ParameterType.FLOAT)))
- .withAnnotations(
- Arrays.asList("datawmzmhcvrfqqmbu", "datati", "datarmcymwr", "datakkaztu"))
- .withFolder(new DatasetFolder().withName("tkedvxhqhp"))
- .withAdditionalProperties(mapOf("type", "Dataset"))),
- new DatasetDebugResource().withName("eforxakpmz")
- .withProperties(new Dataset().withDescription("riottzyru")
- .withStructure("dataihwiezc")
- .withSchema("datazjdplkuyouqnf")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("d")
- .withParameters(mapOf("ffymrzoupipdkgpt", "datajpkvlgahpztvl", "crtpz", "datamym")))
- .withParameters(mapOf("wbzrbqpzgsrphbf",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING), "fytwrnvwaxmey",
- new ParameterSpecification().withType(ParameterType.OBJECT), "mfqmhcqvuqwzaj",
- new ParameterSpecification().withType(ParameterType.BOOL), "maimwufuvtyp",
- new ParameterSpecification().withType(ParameterType.ARRAY)))
+ mapOf("lkvmftrqa", new ParameterSpecification().withType(ParameterType.INT),
+ "uqpoltqvnkofv", new ParameterSpecification().withType(ParameterType.INT)))
.withAnnotations(
- Arrays.asList("datallri", "datakn", "databcgnphengkwh", "dataekxohqvq"))
- .withFolder(new DatasetFolder().withName("oqtvmkjle"))
- .withAdditionalProperties(mapOf("type", "Dataset")))))
- .withLinkedServices(Arrays.asList(new LinkedServiceDebugResource().withName("upsob")
- .withProperties(new LinkedService().withVersion("rgykrcjvoivn")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("ovwkjeguviphxii")
- .withParameters(mapOf("oylpmeccbblg", "datahfrb", "xcrxuyorhrtihzw", "datalej")))
- .withDescription("flwlmh")
- .withParameters(
- mapOf("fosfpgquxqvkuu", new ParameterSpecification().withType(ParameterType.BOOL),
- "hmnvfhyiaxezp", new ParameterSpecification().withType(ParameterType.BOOL), "czqjo",
- new ParameterSpecification().withType(ParameterType.STRING)))
- .withAnnotations(Arrays.asList("datapsgug", "datawokb", "datazpxlxbvhh", "dataa"))
- .withAdditionalProperties(mapOf("type", "LinkedService")))))
+ Arrays.asList("dataddvqtruyzbrk", "datasax", "datahnsepdwxflm", "datacmfidr"))
+ .withAdditionalProperties(mapOf("type", "LinkedService"))),
+ new LinkedServiceDebugResource().withName("fewqnznctnmkits")
+ .withProperties(
+ new LinkedService().withVersion("berydeo")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("efgnibhqie")
+ .withParameters(mapOf("hz", "datapzx", "a", "datantoqfx", "b", "datawclvyxomug",
+ "xd", "dataygwfcwacch")))
+ .withDescription("r")
+ .withParameters(mapOf("qzjzuonttfvjf",
+ new ParameterSpecification().withType(ParameterType.BOOL), "yzbgrgpuavka",
+ new ParameterSpecification().withType(ParameterType.STRING)))
+ .withAnnotations(Arrays.asList("datauxwgz", "datayjpmelvemybo", "datae"))
+ .withAdditionalProperties(mapOf("type", "LinkedService")))))
.withStaging(new DataFlowStagingInfo()
- .withLinkedService(new LinkedServiceReference().withReferenceName("dypwpmyf")
- .withParameters(mapOf("yhenahhpnbvzdfy", "datajx", "dvbnpyedrkgrtda", "datajbzwvnxwduu")))
- .withFolderPath("dataitoimtar"))
+ .withLinkedService(new LinkedServiceReference().withReferenceName("opevqsabo")
+ .withParameters(mapOf("vorzudys", "datanugxnzpqegga", "skwjmqn", "datadiex")))
+ .withFolderPath("dataerggqaohax"))
.withDebugSettings(new DataFlowDebugPackageDebugSettings()
.withSourceSettings(Arrays.asList(
- new DataFlowSourceSetting().withSourceName("bmodbpcduyh")
- .withRowLimit(1956848894)
- .withAdditionalProperties(mapOf()),
- new DataFlowSourceSetting().withSourceName("ibvrfkxi")
- .withRowLimit(792560570)
+ new DataFlowSourceSetting().withSourceName("eior")
+ .withRowLimit(1763863507)
.withAdditionalProperties(mapOf()),
- new DataFlowSourceSetting().withSourceName("rcwzmdenc")
- .withRowLimit(1303417436)
+ new DataFlowSourceSetting().withSourceName("xgidjiijpdbwknbm")
+ .withRowLimit(1164476227)
.withAdditionalProperties(mapOf())))
.withParameters(
- mapOf("qej", "datawxzrkcvbfeuc", "cjkhexxn", "datazhteti", "onmcxriqfr", "dataxlce"))
- .withDatasetParameters("datab"))
- .withAdditionalProperties(mapOf()), com.azure.core.util.Context.NONE)
- .getValue();
+ mapOf("wbgbmp", "datahsltodl", "usq", "datatrsxhiuhgvgno", "wvieymkguvrd", "datadofnp"))
+ .withDatasetParameters("dataproytd"))
+ .withAdditionalProperties(mapOf()),
+ com.azure.core.util.Context.NONE)
+ .getValue();
- Assertions.assertEquals("mgllnyohnhfup", response.jobVersion());
+ Assertions.assertEquals("obpxfgp", response.jobVersion());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsCreateMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsCreateMockTests.java
index 79d4b5ea4f40..abd8337533c6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsCreateMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsCreateMockTests.java
@@ -25,7 +25,7 @@
public final class DataFlowDebugSessionsCreateMockTests {
@Test
public void testCreate() throws Exception {
- String responseStr = "{\"status\":\"dqoqpqyjebg\",\"sessionId\":\"uazwkzedifwdrrgz\"}";
+ String responseStr = "{\"status\":\"mpuqnvn\",\"sessionId\":\"awicou\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -35,17 +35,17 @@ public void testCreate() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
CreateDataFlowDebugSessionResponse response = manager.dataFlowDebugSessions()
- .create("zhdrvkzzvh", "ogjoocnseo",
- new CreateDataFlowDebugSessionRequest().withComputeType("ktqrvzaabeiqo")
- .withCoreCount(1236480850)
- .withTimeToLive(195534639)
- .withIntegrationRuntime(new IntegrationRuntimeDebugResource().withName("fgswpqunvxtvmb")
- .withProperties(new IntegrationRuntime().withDescription("xvqdlwuzkzkhb")
+ .create("ixfosrwzhm", "klocyjpmbtnv",
+ new CreateDataFlowDebugSessionRequest().withComputeType("mhkfkvdmjjiqjv")
+ .withCoreCount(944548630)
+ .withTimeToLive(1599364288)
+ .withIntegrationRuntime(new IntegrationRuntimeDebugResource().withName("feyhny")
+ .withProperties(new IntegrationRuntime().withDescription("i")
.withAdditionalProperties(mapOf("type", "IntegrationRuntime")))),
com.azure.core.util.Context.NONE);
- Assertions.assertEquals("dqoqpqyjebg", response.status());
- Assertions.assertEquals("uazwkzedifwdrrgz", response.sessionId());
+ Assertions.assertEquals("mpuqnvn", response.status());
+ Assertions.assertEquals("awicou", response.sessionId());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsDeleteWithResponseMockTests.java
index 5f85f91b5977..b3b2c92d354f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsDeleteWithResponseMockTests.java
@@ -29,8 +29,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.dataFlowDebugSessions()
- .deleteWithResponse("xfos", "wzhmlklocyjpmbt",
- new DeleteDataFlowDebugSessionRequest().withSessionId("xomhkfkvdmjjiqjv"),
+ .deleteWithResponse("dzdzswvfwiunj", "qx", new DeleteDataFlowDebugSessionRequest().withSessionId("tfzgdq"),
com.azure.core.util.Context.NONE);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsExecuteCommandMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsExecuteCommandMockTests.java
index 68319c6ecd9f..88e244de80c8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsExecuteCommandMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsExecuteCommandMockTests.java
@@ -24,7 +24,7 @@
public final class DataFlowDebugSessionsExecuteCommandMockTests {
@Test
public void testExecuteCommand() throws Exception {
- String responseStr = "{\"status\":\"nvnxsa\",\"data\":\"couilbjccj\"}";
+ String responseStr = "{\"status\":\"lkflffo\",\"data\":\"skndwyw\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -34,16 +34,16 @@ public void testExecuteCommand() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
DataFlowDebugCommandResponse response = manager.dataFlowDebugSessions()
- .executeCommand("fiomfkiopk", "hbfnhspogxuv",
- new DataFlowDebugCommandRequest().withSessionId("my")
+ .executeCommand("wvbiryxsaxwu", "pnsesxwkhkcdt",
+ new DataFlowDebugCommandRequest().withSessionId("a")
.withCommand(DataFlowDebugCommandType.EXECUTE_PREVIEW_QUERY)
- .withCommandPayload(new DataFlowDebugCommandPayload().withStreamName("ayfkvw")
- .withRowLimits(1637727011)
- .withColumns(Arrays.asList("yh", "yn"))
- .withExpression("p")),
+ .withCommandPayload(new DataFlowDebugCommandPayload().withStreamName("qfzvvtifcqsuem")
+ .withRowLimits(271273488)
+ .withColumns(Arrays.asList("ovbpn", "fucxtmhmzcnpsd", "fwjcwwbunf", "mbwinura"))
+ .withExpression("bmjokttqgokhaj")),
com.azure.core.util.Context.NONE);
- Assertions.assertEquals("nvnxsa", response.status());
- Assertions.assertEquals("couilbjccj", response.data());
+ Assertions.assertEquals("lkflffo", response.status());
+ Assertions.assertEquals("skndwyw", response.data());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsQueryByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsQueryByFactoryMockTests.java
index ed6b715a11cd..1d7b80ddcdee 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsQueryByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowDebugSessionsQueryByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class DataFlowDebugSessionsQueryByFactoryMockTests {
@Test
public void testQueryByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"dataFlowName\":\"lxqjshyyrc\",\"computeType\":\"wzqsfaurmqpkgwfb\",\"coreCount\":570698010,\"nodeCount\":1408597782,\"integrationRuntimeName\":\"rhhxlibdn\",\"sessionId\":\"amslvpxsy\",\"startTime\":\"ifv\",\"timeToLiveInMinutes\":1795872243,\"lastActivityTime\":\"aauls\",\"\":{\"gx\":\"datahvcvveb\",\"bhkyas\":\"datarpho\"}}]}";
+ = "{\"value\":[{\"dataFlowName\":\"zqcymdj\",\"computeType\":\"ojykytpyirctdaoj\",\"coreCount\":733493660,\"nodeCount\":550438817,\"integrationRuntimeName\":\"ikqagmlhs\",\"sessionId\":\"pihenvhlpuobha\",\"startTime\":\"aowpm\",\"timeToLiveInMinutes\":701601830,\"lastActivityTime\":\"uziogboaimwxswfy\",\"\":{\"gtgc\":\"datacjhjrwn\",\"w\":\"datampjdrhxfg\"}}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,16 +32,16 @@ public void testQueryByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response = manager.dataFlowDebugSessions()
- .queryByFactory("uupw", "oohzifbbsncorini", com.azure.core.util.Context.NONE);
+ .queryByFactory("lbjccjorovr", "dfgdvifo", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("lxqjshyyrc", response.iterator().next().dataFlowName());
- Assertions.assertEquals("wzqsfaurmqpkgwfb", response.iterator().next().computeType());
- Assertions.assertEquals(570698010, response.iterator().next().coreCount());
- Assertions.assertEquals(1408597782, response.iterator().next().nodeCount());
- Assertions.assertEquals("rhhxlibdn", response.iterator().next().integrationRuntimeName());
- Assertions.assertEquals("amslvpxsy", response.iterator().next().sessionId());
- Assertions.assertEquals("ifv", response.iterator().next().startTime());
- Assertions.assertEquals(1795872243, response.iterator().next().timeToLiveInMinutes());
- Assertions.assertEquals("aauls", response.iterator().next().lastActivityTime());
+ Assertions.assertEquals("zqcymdj", response.iterator().next().dataFlowName());
+ Assertions.assertEquals("ojykytpyirctdaoj", response.iterator().next().computeType());
+ Assertions.assertEquals(733493660, response.iterator().next().coreCount());
+ Assertions.assertEquals(550438817, response.iterator().next().nodeCount());
+ Assertions.assertEquals("ikqagmlhs", response.iterator().next().integrationRuntimeName());
+ Assertions.assertEquals("pihenvhlpuobha", response.iterator().next().sessionId());
+ Assertions.assertEquals("aowpm", response.iterator().next().startTime());
+ Assertions.assertEquals(701601830, response.iterator().next().timeToLiveInMinutes());
+ Assertions.assertEquals("uziogboaimwxswfy", response.iterator().next().lastActivityTime());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsCreateOrUpdateWithResponseMockTests.java
index 3c9f83c3015d..8d0120f03def 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsCreateOrUpdateWithResponseMockTests.java
@@ -24,7 +24,7 @@ public final class DataFlowsCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"DataFlow\",\"description\":\"ojtryrdzogtrycbm\",\"annotations\":[\"datawmavgdztdjs\"],\"folder\":{\"name\":\"kbcwymbpredcl\"}},\"name\":\"lvuzqsv\",\"type\":\"rkpswasveymdrbm\",\"etag\":\"cryyykwwhscubgwz\",\"id\":\"nplzbzc\"}";
+ = "{\"properties\":{\"type\":\"DataFlow\",\"description\":\"lcekonmcxriqfrrx\",\"annotations\":[\"datavrhcjhszmymfr\",\"dataosmic\",\"datakizqqdawmrk\"],\"folder\":{\"name\":\"xbbhjgnjlzdjzhx\"}},\"name\":\"bxsok\",\"type\":\"awr\",\"etag\":\"rodrtkw\",\"id\":\"gllnyohnhfu\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -34,16 +34,16 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
DataFlowResource response = manager.dataFlows()
- .define("mouxspkxapqgyh")
- .withExistingFactory("jsyors", "jvztqragq")
- .withProperties(new DataFlow().withDescription("qkkwzbgbwwop")
- .withAnnotations(Arrays.asList("datawse", "datarzcnlqs"))
- .withFolder(new DataFlowFolder().withName("kbt")))
- .withIfMatch("lbflbax")
+ .define("ya")
+ .withExistingFactory("iixnx", "cvyi")
+ .withProperties(new DataFlow().withDescription("wegijdejs")
+ .withAnnotations(Arrays.asList("datacggoqmblhcba"))
+ .withFolder(new DataFlowFolder().withName("waathdrbaaqt")))
+ .withIfMatch("exxn")
.create();
- Assertions.assertEquals("nplzbzc", response.id());
- Assertions.assertEquals("ojtryrdzogtrycbm", response.properties().description());
- Assertions.assertEquals("kbcwymbpredcl", response.properties().folder().name());
+ Assertions.assertEquals("gllnyohnhfu", response.id());
+ Assertions.assertEquals("lcekonmcxriqfrrx", response.properties().description());
+ Assertions.assertEquals("xbbhjgnjlzdjzhx", response.properties().folder().name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsDeleteWithResponseMockTests.java
index 8c01ae8e4c27..4fe1e25eb4c9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsDeleteWithResponseMockTests.java
@@ -27,7 +27,8 @@ public void testDeleteWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.dataFlows().deleteWithResponse("ek", "lioagvijr", "yotejljdrerzjwex", com.azure.core.util.Context.NONE);
+ manager.dataFlows()
+ .deleteWithResponse("vuj", "ukadzuftxfqddade", "nsaecdcvhxwegd", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsGetWithResponseMockTests.java
index e684ba0cba73..f79e68faddbf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class DataFlowsGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"DataFlow\",\"description\":\"hgrgiu\",\"annotations\":[\"dataykvo\",\"datakjixbrdam\",\"dataneb\",\"dataonflknmzaih\"],\"folder\":{\"name\":\"scseuhh\"}},\"name\":\"hspvbwjmtlavuecm\",\"type\":\"corydjsaki\",\"etag\":\"lmiglnqrmqefdq\",\"id\":\"sfebhvkkpd\"}";
+ = "{\"properties\":{\"type\":\"DataFlow\",\"description\":\"vmfosfpgqux\",\"annotations\":[\"datauuyehmnvfhyiax\",\"datazpwhczqjoov\",\"datapsgug\"],\"folder\":{\"name\":\"kbw\"}},\"name\":\"x\",\"type\":\"bvhhkabeoxh\",\"etag\":\"et\",\"id\":\"mtqnsigrqcxhwvz\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,11 +31,11 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
DataFlowResource response = manager.dataFlows()
- .getWithResponse("hxjwiggca", "mkoxpay", "zqgsaegaah", "ger", com.azure.core.util.Context.NONE)
+ .getWithResponse("wlejcxc", "xu", "orhrtihzwd", "flwlmh", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("sfebhvkkpd", response.id());
- Assertions.assertEquals("hgrgiu", response.properties().description());
- Assertions.assertEquals("scseuhh", response.properties().folder().name());
+ Assertions.assertEquals("mtqnsigrqcxhwvz", response.id());
+ Assertions.assertEquals("vmfosfpgqux", response.properties().description());
+ Assertions.assertEquals("kbw", response.properties().folder().name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsListByFactoryMockTests.java
index c9c05ef997d3..2ef2f34e0df7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataFlowsListByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class DataFlowsListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"type\":\"DataFlow\",\"description\":\"megcjsn\",\"annotations\":[\"datapqotfdbiljsid\"],\"folder\":{\"name\":\"tr\"}},\"name\":\"lauupwt\",\"type\":\"pbinabsegco\",\"etag\":\"ctekaajuwkxb\",\"id\":\"edfc\"}]}";
+ = "{\"value\":[{\"properties\":{\"type\":\"DataFlow\",\"description\":\"pwpmyftvejxm\",\"annotations\":[\"datanahhpnbvzdf\",\"dataxjbzwvnxwdu\",\"datawdvbnpyed\"],\"folder\":{\"name\":\"rtdaqlitoimta\"}},\"name\":\"fexkbmodbpc\",\"type\":\"yhhzcjzgij\",\"etag\":\"clloejshfc\",\"id\":\"zujcibvrfk\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,10 +32,10 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.dataFlows().listByFactory("rrxbeufz", "ddcxfuizo", com.azure.core.util.Context.NONE);
+ = manager.dataFlows().listByFactory("mnyphvx", "lupsobqpd", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("edfc", response.iterator().next().id());
- Assertions.assertEquals("megcjsn", response.iterator().next().properties().description());
- Assertions.assertEquals("tr", response.iterator().next().properties().folder().name());
+ Assertions.assertEquals("zujcibvrfk", response.iterator().next().id());
+ Assertions.assertEquals("pwpmyftvejxm", response.iterator().next().properties().description());
+ Assertions.assertEquals("rtdaqlitoimta", response.iterator().next().properties().folder().name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTests.java
index 2c17baf86a39..b70054b6678b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTests.java
@@ -22,63 +22,63 @@ public final class DataLakeAnalyticsUsqlActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DataLakeAnalyticsUsqlActivity model = BinaryData.fromString(
- "{\"type\":\"DataLakeAnalyticsU-SQL\",\"typeProperties\":{\"scriptPath\":\"datagstmlhrziggc\",\"scriptLinkedService\":{\"referenceName\":\"zynimkk\",\"parameters\":{\"douicho\":\"dataowcutohmxmj\"}},\"degreeOfParallelism\":\"datamenn\",\"priority\":\"dataqjakqdqnne\",\"parameters\":{\"eqllrpcqyxqf\":\"datauuguzesfgg\",\"qeqtlsipedgtup\":\"datarvmvdqhageho\"},\"runtimeVersion\":\"datavxeubngwidgxy\",\"compilationMode\":\"dataovlph\"},\"linkedServiceName\":{\"referenceName\":\"mfvyhmivy\",\"parameters\":{\"k\":\"datao\"}},\"policy\":{\"timeout\":\"dataoprgcs\",\"retry\":\"datacorxibwsf\",\"retryIntervalInSeconds\":817850977,\"secureInput\":false,\"secureOutput\":true,\"\":{\"assclgolbpwegz\":\"dataxenmuev\",\"k\":\"dataionlgnes\"}},\"name\":\"nhfd\",\"description\":\"skv\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"hlbxrqbi\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Completed\"],\"\":{\"c\":\"dataxxiizkehfkp\"}}],\"userProperties\":[{\"name\":\"wbkrwihb\",\"value\":\"dataufmui\"},{\"name\":\"hqpqfowxdihux\",\"value\":\"datadgotoon\"}],\"\":{\"jqxknaeuhxnpad\":\"datai\",\"dvnaxtbnjmj\":\"datajaeqaolfyqjgob\",\"bdfmhzgtieybimit\":\"datagrwvl\",\"wab\":\"dataxeetkwloozeg\"}}")
+ "{\"type\":\"DataLakeAnalyticsU-SQL\",\"typeProperties\":{\"scriptPath\":\"datalfrwym\",\"scriptLinkedService\":{\"referenceName\":\"ujtnnd\",\"parameters\":{\"pljyt\":\"datayc\",\"fxhzvrsrgbfaqg\":\"dataqbtijybpfwgclppw\"}},\"degreeOfParallelism\":\"datakisipjgvm\",\"priority\":\"dataurr\",\"parameters\":{\"bwjopk\":\"datazbxu\",\"bwffgconiydgn\":\"datadubq\"},\"runtimeVersion\":\"datagyytn\",\"compilationMode\":\"datalankosd\"},\"linkedServiceName\":{\"referenceName\":\"mf\",\"parameters\":{\"ybdivxvxw\":\"dataefkhki\",\"czco\":\"datafmqzndlgqtuq\"}},\"policy\":{\"timeout\":\"datacwtxaafcvqhmsdo\",\"retry\":\"datarzsninkhbm\",\"retryIntervalInSeconds\":1593239802,\"secureInput\":false,\"secureOutput\":false,\"\":{\"mcp\":\"dataphz\",\"qzxkpxrful\":\"dataepkrdge\",\"bp\":\"datahhmnd\",\"jmel\":\"datadg\"}},\"name\":\"kzmfmgboyliopbo\",\"description\":\"faiyvmpfebsummy\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"xsdup\",\"dependencyConditions\":[\"Failed\",\"Skipped\"],\"\":{\"vh\":\"datahgb\",\"zvclzutvqkoi\":\"dataskos\"}}],\"userProperties\":[{\"name\":\"pfskqwjlohkaffyn\",\"value\":\"datawvbqbytyijxkuc\"},{\"name\":\"pqp\",\"value\":\"dataxkayvxegiufjnjg\"}],\"\":{\"unuvawmxx\":\"datajppbalcftiwbd\",\"pzqrb\":\"datao\",\"wrufiouafxp\":\"datayza\"}}")
.toObject(DataLakeAnalyticsUsqlActivity.class);
- Assertions.assertEquals("nhfd", model.name());
- Assertions.assertEquals("skv", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("hlbxrqbi", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("wbkrwihb", model.userProperties().get(0).name());
- Assertions.assertEquals("mfvyhmivy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(817850977, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("kzmfmgboyliopbo", model.name());
+ Assertions.assertEquals("faiyvmpfebsummy", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("xsdup", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("pfskqwjlohkaffyn", model.userProperties().get(0).name());
+ Assertions.assertEquals("mf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1593239802, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(true, model.policy().secureOutput());
- Assertions.assertEquals("zynimkk", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals(false, model.policy().secureOutput());
+ Assertions.assertEquals("ujtnnd", model.scriptLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DataLakeAnalyticsUsqlActivity model = new DataLakeAnalyticsUsqlActivity().withName("nhfd")
- .withDescription("skv")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("hlbxrqbi")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED,
- DependencyCondition.COMPLETED))
+ DataLakeAnalyticsUsqlActivity model = new DataLakeAnalyticsUsqlActivity().withName("kzmfmgboyliopbo")
+ .withDescription("faiyvmpfebsummy")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("xsdup")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("wbkrwihb").withValue("dataufmui"),
- new UserProperty().withName("hqpqfowxdihux").withValue("datadgotoon")))
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("mfvyhmivy").withParameters(mapOf("k", "datao")))
- .withPolicy(new ActivityPolicy().withTimeout("dataoprgcs")
- .withRetry("datacorxibwsf")
- .withRetryIntervalInSeconds(817850977)
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("pfskqwjlohkaffyn").withValue("datawvbqbytyijxkuc"),
+ new UserProperty().withName("pqp").withValue("dataxkayvxegiufjnjg")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mf")
+ .withParameters(mapOf("ybdivxvxw", "dataefkhki", "czco", "datafmqzndlgqtuq")))
+ .withPolicy(new ActivityPolicy().withTimeout("datacwtxaafcvqhmsdo")
+ .withRetry("datarzsninkhbm")
+ .withRetryIntervalInSeconds(1593239802)
.withSecureInput(false)
- .withSecureOutput(true)
+ .withSecureOutput(false)
.withAdditionalProperties(mapOf()))
- .withScriptPath("datagstmlhrziggc")
- .withScriptLinkedService(new LinkedServiceReference().withReferenceName("zynimkk")
- .withParameters(mapOf("douicho", "dataowcutohmxmj")))
- .withDegreeOfParallelism("datamenn")
- .withPriority("dataqjakqdqnne")
- .withParameters(mapOf("eqllrpcqyxqf", "datauuguzesfgg", "qeqtlsipedgtup", "datarvmvdqhageho"))
- .withRuntimeVersion("datavxeubngwidgxy")
- .withCompilationMode("dataovlph");
+ .withScriptPath("datalfrwym")
+ .withScriptLinkedService(new LinkedServiceReference().withReferenceName("ujtnnd")
+ .withParameters(mapOf("pljyt", "datayc", "fxhzvrsrgbfaqg", "dataqbtijybpfwgclppw")))
+ .withDegreeOfParallelism("datakisipjgvm")
+ .withPriority("dataurr")
+ .withParameters(mapOf("bwjopk", "datazbxu", "bwffgconiydgn", "datadubq"))
+ .withRuntimeVersion("datagyytn")
+ .withCompilationMode("datalankosd");
model = BinaryData.fromObject(model).toObject(DataLakeAnalyticsUsqlActivity.class);
- Assertions.assertEquals("nhfd", model.name());
- Assertions.assertEquals("skv", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("hlbxrqbi", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("wbkrwihb", model.userProperties().get(0).name());
- Assertions.assertEquals("mfvyhmivy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(817850977, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("kzmfmgboyliopbo", model.name());
+ Assertions.assertEquals("faiyvmpfebsummy", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("xsdup", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("pfskqwjlohkaffyn", model.userProperties().get(0).name());
+ Assertions.assertEquals("mf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1593239802, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(true, model.policy().secureOutput());
- Assertions.assertEquals("zynimkk", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals(false, model.policy().secureOutput());
+ Assertions.assertEquals("ujtnnd", model.scriptLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTypePropertiesTests.java
index ed4a6ecd4447..ae8abfe86d2f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DataLakeAnalyticsUsqlActivityTypePropertiesTests.java
@@ -15,26 +15,24 @@ public final class DataLakeAnalyticsUsqlActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DataLakeAnalyticsUsqlActivityTypeProperties model = BinaryData.fromString(
- "{\"scriptPath\":\"datarrreftwhiivxy\",\"scriptLinkedService\":{\"referenceName\":\"vjezikuzlfnbzek\",\"parameters\":{\"yhncqyo\":\"datajbkwrvc\",\"nxggwx\":\"datavvpxsd\",\"ykovgxamhmq\":\"dataqyhtlnnpft\"}},\"degreeOfParallelism\":\"datayoylcwzkcreufdp\",\"priority\":\"dataelcrwh\",\"parameters\":{\"uvbo\":\"datasxybalsmia\",\"byyvxjelsjhgrvy\":\"dataqzypvc\",\"ikujjdoelaw\":\"dataluhkhiycddon\",\"kotvoszgcy\":\"databkez\"},\"runtimeVersion\":\"datajxnahqwvvferl\",\"compilationMode\":\"datafz\"}")
+ "{\"scriptPath\":\"dataqzmwxoogi\",\"scriptLinkedService\":{\"referenceName\":\"gnplzbtvpuigtnjy\",\"parameters\":{\"extlyyvebpykzhr\":\"datavvitxoitnqmiwlri\"}},\"degreeOfParallelism\":\"datasbtwpvmz\",\"priority\":\"dataxepapmv\",\"parameters\":{\"kylu\":\"datas\",\"tefbbr\":\"dataxndmtasxsnb\",\"oh\":\"datalofkvshozjkwjwv\"},\"runtimeVersion\":\"datasg\",\"compilationMode\":\"datafzstyacbekc\"}")
.toObject(DataLakeAnalyticsUsqlActivityTypeProperties.class);
- Assertions.assertEquals("vjezikuzlfnbzek", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals("gnplzbtvpuigtnjy", model.scriptLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DataLakeAnalyticsUsqlActivityTypeProperties model
- = new DataLakeAnalyticsUsqlActivityTypeProperties().withScriptPath("datarrreftwhiivxy")
- .withScriptLinkedService(new LinkedServiceReference().withReferenceName("vjezikuzlfnbzek")
- .withParameters(
- mapOf("yhncqyo", "datajbkwrvc", "nxggwx", "datavvpxsd", "ykovgxamhmq", "dataqyhtlnnpft")))
- .withDegreeOfParallelism("datayoylcwzkcreufdp")
- .withPriority("dataelcrwh")
- .withParameters(mapOf("uvbo", "datasxybalsmia", "byyvxjelsjhgrvy", "dataqzypvc", "ikujjdoelaw",
- "dataluhkhiycddon", "kotvoszgcy", "databkez"))
- .withRuntimeVersion("datajxnahqwvvferl")
- .withCompilationMode("datafz");
+ = new DataLakeAnalyticsUsqlActivityTypeProperties().withScriptPath("dataqzmwxoogi")
+ .withScriptLinkedService(new LinkedServiceReference().withReferenceName("gnplzbtvpuigtnjy")
+ .withParameters(mapOf("extlyyvebpykzhr", "datavvitxoitnqmiwlri")))
+ .withDegreeOfParallelism("datasbtwpvmz")
+ .withPriority("dataxepapmv")
+ .withParameters(mapOf("kylu", "datas", "tefbbr", "dataxndmtasxsnb", "oh", "datalofkvshozjkwjwv"))
+ .withRuntimeVersion("datasg")
+ .withCompilationMode("datafzstyacbekc");
model = BinaryData.fromObject(model).toObject(DataLakeAnalyticsUsqlActivityTypeProperties.class);
- Assertions.assertEquals("vjezikuzlfnbzek", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals("gnplzbtvpuigtnjy", model.scriptLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTests.java
index 2d92bfd1cfba..61a7b6bb1744 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTests.java
@@ -22,68 +22,66 @@ public final class DatabricksNotebookActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DatabricksNotebookActivity model = BinaryData.fromString(
- "{\"type\":\"DatabricksNotebook\",\"typeProperties\":{\"notebookPath\":\"dataga\",\"baseParameters\":{\"sxu\":\"datair\",\"zchkww\":\"databnbofyeggaauubk\",\"lujwcyvpxbqujno\":\"databxjpytkakhvao\",\"gwzvdqpxicpozzhf\":\"datafxirjcc\"},\"libraries\":[{\"ps\":\"dataqpc\",\"fkzu\":\"datardkdomyqbeasbvz\",\"bmfqtnqaqlt\":\"datazqudqgfr\"},{\"yfitdprbmmfqte\":\"datahfphawjovqtvbusy\",\"egykzdspbjk\":\"dataxgikdcjmbwrhpwtu\",\"gerangxnafo\":\"datandsrwhjhi\"},{\"qcxrvwduspxij\":\"dataq\",\"yvzpv\":\"dataremvzqc\",\"ucfsup\":\"datasduzfyb\",\"yjwxwpoywymtw\":\"dataqpg\"},{\"x\":\"datadgbg\",\"gia\":\"datazrzhkhmw\",\"nlzalsuj\":\"datarftpgqxnyoakd\"}]},\"linkedServiceName\":{\"referenceName\":\"gz\",\"parameters\":{\"bmfejtdboa\":\"databce\",\"jypgbhfzypy\":\"datanya\"}},\"policy\":{\"timeout\":\"datarlrjgrzxaa\",\"retry\":\"databhkaqzahjqslshc\",\"retryIntervalInSeconds\":1784468344,\"secureInput\":true,\"secureOutput\":false,\"\":{\"co\":\"datagsnf\",\"upaqzithojrtcdav\":\"datat\",\"wezwkparj\":\"datarifmtk\"}},\"name\":\"xirsvjozexxzkci\",\"description\":\"keawrumhz\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"gsshdubq\",\"dependencyConditions\":[\"Failed\"],\"\":{\"khi\":\"databomw\",\"wbormfnntpocf\":\"dataqiqx\",\"dohytkhq\":\"datavmzs\"}},{\"activity\":\"h\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Failed\"],\"\":{\"eaivbzrmsoeddwji\":\"datamttsw\",\"oatfiomd\":\"datarzavciffqameccuq\"}},{\"activity\":\"ecrbcvhkkdsy\",\"dependencyConditions\":[\"Completed\",\"Succeeded\"],\"\":{\"xluqpzwlbccxjbal\":\"databzohvpq\"}}],\"userProperties\":[{\"name\":\"jnknfv\",\"value\":\"dataavr\"}],\"\":{\"qcvan\":\"dataib\",\"s\":\"datauiiprfijmil\"}}")
+ "{\"type\":\"DatabricksNotebook\",\"typeProperties\":{\"notebookPath\":\"datalzqmwmwoggbxias\",\"baseParameters\":{\"lfedwhvhlzpvpix\":\"dataucnp\",\"vc\":\"datajvycodfubnvdibb\",\"nmptxlrvkl\":\"databtmh\",\"sdi\":\"datapauqya\"},\"libraries\":[{\"bvahj\":\"datavksoxykrmalen\",\"gojopsgedsyyku\":\"datavbnlxe\"},{\"ntlf\":\"datafmt\",\"vazffzhbh\":\"dataiq\"},{\"cy\":\"datagwlrdgpudbimehd\",\"ut\":\"datayfhwkbhapfnyo\"}]},\"linkedServiceName\":{\"referenceName\":\"ehjrmf\",\"parameters\":{\"zcpyirngfujvx\":\"dataihnhwgzunbcv\"}},\"policy\":{\"timeout\":\"dataqqf\",\"retry\":\"datadobutkqwrsxxcaxg\",\"retryIntervalInSeconds\":1935871213,\"secureInput\":true,\"secureOutput\":false,\"\":{\"fcblv\":\"datanchrvsfnlgwpuas\",\"dhdiiwvz\":\"datakhdigxxtfvoa\",\"tm\":\"dataffm\",\"hxpmtz\":\"dataartpdyhbpfxm\"}},\"name\":\"vxfglilfjcowr\",\"description\":\"yocjxsgrtnita\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"vp\",\"dependencyConditions\":[\"Succeeded\",\"Failed\"],\"\":{\"t\":\"datanffexzzijt\",\"plwyluvqp\":\"dataewniwt\"}},{\"activity\":\"wvoyqsnt\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Skipped\",\"Skipped\"],\"\":{\"sxcqto\":\"dataaldss\"}},{\"activity\":\"oanxinlm\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"s\":\"databuiv\"}}],\"userProperties\":[{\"name\":\"nenhyhdu\",\"value\":\"dataayk\"},{\"name\":\"jhwybbdaedq\",\"value\":\"datatzsltsxmdace\"}],\"\":{\"qjxdirdcxuiam\":\"dataapfieau\",\"fyivvtxqp\":\"dataxlhfxjcqofpwjjtd\",\"dbjd\":\"datamqogtohzfvysv\",\"mzjppblnervt\":\"datahtxvmnyslpdq\"}}")
.toObject(DatabricksNotebookActivity.class);
- Assertions.assertEquals("xirsvjozexxzkci", model.name());
- Assertions.assertEquals("keawrumhz", model.description());
+ Assertions.assertEquals("vxfglilfjcowr", model.name());
+ Assertions.assertEquals("yocjxsgrtnita", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("gsshdubq", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jnknfv", model.userProperties().get(0).name());
- Assertions.assertEquals("gz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1784468344, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("vp", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("nenhyhdu", model.userProperties().get(0).name());
+ Assertions.assertEquals("ehjrmf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1935871213, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DatabricksNotebookActivity model = new DatabricksNotebookActivity().withName("xirsvjozexxzkci")
- .withDescription("keawrumhz")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("gsshdubq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("h")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED,
- DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ecrbcvhkkdsy")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("jnknfv").withValue("dataavr")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("gz")
- .withParameters(mapOf("bmfejtdboa", "databce", "jypgbhfzypy", "datanya")))
- .withPolicy(new ActivityPolicy().withTimeout("datarlrjgrzxaa")
- .withRetry("databhkaqzahjqslshc")
- .withRetryIntervalInSeconds(1784468344)
- .withSecureInput(true)
- .withSecureOutput(false)
- .withAdditionalProperties(mapOf()))
- .withNotebookPath("dataga")
- .withBaseParameters(mapOf("sxu", "datair", "zchkww", "databnbofyeggaauubk", "lujwcyvpxbqujno",
- "databxjpytkakhvao", "gwzvdqpxicpozzhf", "datafxirjcc"))
- .withLibraries(
- Arrays.asList(mapOf("ps", "dataqpc", "fkzu", "datardkdomyqbeasbvz", "bmfqtnqaqlt", "datazqudqgfr"),
- mapOf("yfitdprbmmfqte", "datahfphawjovqtvbusy", "egykzdspbjk", "dataxgikdcjmbwrhpwtu",
- "gerangxnafo", "datandsrwhjhi"),
- mapOf("qcxrvwduspxij", "dataq", "yvzpv", "dataremvzqc", "ucfsup", "datasduzfyb", "yjwxwpoywymtw",
- "dataqpg"),
- mapOf("x", "datadgbg", "gia", "datazrzhkhmw", "nlzalsuj", "datarftpgqxnyoakd")));
+ DatabricksNotebookActivity model
+ = new DatabricksNotebookActivity().withName("vxfglilfjcowr")
+ .withDescription("yocjxsgrtnita")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("vp")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("wvoyqsnt")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.COMPLETED, DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("oanxinlm")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("nenhyhdu").withValue("dataayk"),
+ new UserProperty().withName("jhwybbdaedq").withValue("datatzsltsxmdace")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ehjrmf")
+ .withParameters(mapOf("zcpyirngfujvx", "dataihnhwgzunbcv")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataqqf")
+ .withRetry("datadobutkqwrsxxcaxg")
+ .withRetryIntervalInSeconds(1935871213)
+ .withSecureInput(true)
+ .withSecureOutput(false)
+ .withAdditionalProperties(mapOf()))
+ .withNotebookPath("datalzqmwmwoggbxias")
+ .withBaseParameters(mapOf("lfedwhvhlzpvpix", "dataucnp", "vc", "datajvycodfubnvdibb", "nmptxlrvkl",
+ "databtmh", "sdi", "datapauqya"))
+ .withLibraries(Arrays.asList(mapOf("bvahj", "datavksoxykrmalen", "gojopsgedsyyku", "datavbnlxe"),
+ mapOf("ntlf", "datafmt", "vazffzhbh", "dataiq"),
+ mapOf("cy", "datagwlrdgpudbimehd", "ut", "datayfhwkbhapfnyo")));
model = BinaryData.fromObject(model).toObject(DatabricksNotebookActivity.class);
- Assertions.assertEquals("xirsvjozexxzkci", model.name());
- Assertions.assertEquals("keawrumhz", model.description());
+ Assertions.assertEquals("vxfglilfjcowr", model.name());
+ Assertions.assertEquals("yocjxsgrtnita", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("gsshdubq", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jnknfv", model.userProperties().get(0).name());
- Assertions.assertEquals("gz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1784468344, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("vp", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("nenhyhdu", model.userProperties().get(0).name());
+ Assertions.assertEquals("ehjrmf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1935871213, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTypePropertiesTests.java
index d86e1e151e45..fd857bdaa253 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksNotebookActivityTypePropertiesTests.java
@@ -14,17 +14,19 @@ public final class DatabricksNotebookActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DatabricksNotebookActivityTypeProperties model = BinaryData.fromString(
- "{\"notebookPath\":\"datadxsphfjzxeswzg\",\"baseParameters\":{\"sjeolxbg\":\"datagggj\",\"twehvuttngatgl\":\"dataojoe\"},\"libraries\":[{\"eahypjqag\":\"datazguarkrfabf\"},{\"u\":\"datau\",\"mwae\":\"datalffpvdjfwsibplb\"},{\"hnhcxhf\":\"datab\",\"d\":\"datahabn\"}]}")
+ "{\"notebookPath\":\"datamz\",\"baseParameters\":{\"yyasildbqygnfxg\":\"datajxvt\",\"bkbjs\":\"datazqqwsvjhmqp\",\"pe\":\"datagkdvm\"},\"libraries\":[{\"nshoefdsgfz\":\"datagy\",\"uoavpoookhcurwg\":\"datamh\"},{\"hgsutseejtfnjrr\":\"datazznmjwqwy\",\"xnbbsjgvalowmmh\":\"datafbuywzp\",\"tceehqeahlfujp\":\"datauhywdckvcof\",\"uumldunalo\":\"datavtakijwkwed\"},{\"sszucdvhq\":\"datanikfqcbeu\",\"t\":\"datacqqiulwfzoszgb\"}]}")
.toObject(DatabricksNotebookActivityTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DatabricksNotebookActivityTypeProperties model
- = new DatabricksNotebookActivityTypeProperties().withNotebookPath("datadxsphfjzxeswzg")
- .withBaseParameters(mapOf("sjeolxbg", "datagggj", "twehvuttngatgl", "dataojoe"))
- .withLibraries(Arrays.asList(mapOf("eahypjqag", "datazguarkrfabf"),
- mapOf("u", "datau", "mwae", "datalffpvdjfwsibplb"), mapOf("hnhcxhf", "datab", "d", "datahabn")));
+ = new DatabricksNotebookActivityTypeProperties().withNotebookPath("datamz")
+ .withBaseParameters(mapOf("yyasildbqygnfxg", "datajxvt", "bkbjs", "datazqqwsvjhmqp", "pe", "datagkdvm"))
+ .withLibraries(Arrays.asList(mapOf("nshoefdsgfz", "datagy", "uoavpoookhcurwg", "datamh"),
+ mapOf("hgsutseejtfnjrr", "datazznmjwqwy", "xnbbsjgvalowmmh", "datafbuywzp", "tceehqeahlfujp",
+ "datauhywdckvcof", "uumldunalo", "datavtakijwkwed"),
+ mapOf("sszucdvhq", "datanikfqcbeu", "t", "datacqqiulwfzoszgb")));
model = BinaryData.fromObject(model).toObject(DatabricksNotebookActivityTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTests.java
index 5cbbc1ff5bc2..918bc9aa7f49 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTests.java
@@ -22,69 +22,59 @@ public final class DatabricksSparkJarActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DatabricksSparkJarActivity model = BinaryData.fromString(
- "{\"type\":\"DatabricksSparkJar\",\"typeProperties\":{\"mainClassName\":\"databtymhh\",\"parameters\":[\"datacmwix\",\"datarvrpujb\"],\"libraries\":[{\"gteihmvxupqfaww\":\"datay\",\"snynvgf\":\"dataxqjhmfyvgmdwv\"}]},\"linkedServiceName\":{\"referenceName\":\"tokipndek\",\"parameters\":{\"rotnvxyeqdin\":\"datadrkddzkki\",\"xlpgrvtzj\":\"dataqsejtqoxeth\"}},\"policy\":{\"timeout\":\"datasrejqwylh\",\"retry\":\"datamho\",\"retryIntervalInSeconds\":1180067892,\"secureInput\":true,\"secureOutput\":false,\"\":{\"xtxhxfsknmrce\":\"dataomxyxnben\",\"woflfniislohftm\":\"datadfbdxwywdyqpkw\",\"rxryaicyvtsg\":\"datam\",\"qopoe\":\"datapmatubtejipqynrl\"}},\"name\":\"qf\",\"description\":\"xthcdzeuck\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"nikoybr\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Skipped\"],\"\":{\"ymis\":\"datatzhiku\",\"l\":\"dataoxmzvlofzdnvsr\"}},{\"activity\":\"wzuj\",\"dependencyConditions\":[\"Completed\"],\"\":{\"cxtxgrhaqbst\":\"datavxrqegk\",\"sffeql\":\"datadeuvsbsdcoq\",\"rjrx\":\"datakpvsij\",\"occeyeqsehkq\":\"datacnfyknx\"}},{\"activity\":\"lldeksgejmpkqtj\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Succeeded\",\"Completed\"],\"\":{\"uoqbclhn\":\"datahpkaamoovrbv\",\"kzhqpkckwaafu\":\"dataqxuxrggx\",\"hpijurqoihxibji\":\"datascjaw\"}},{\"activity\":\"m\",\"dependencyConditions\":[\"Completed\"],\"\":{\"nbluxomzg\":\"datafurdjjzsijmsaa\",\"wuiopgyunf\":\"datajmnvukovxfkxnevc\"}}],\"userProperties\":[{\"name\":\"oycg\",\"value\":\"datakik\"},{\"name\":\"q\",\"value\":\"datadiihmpmfa\"},{\"name\":\"inodekp\",\"value\":\"datacpwcxfnuysrvxaym\"},{\"name\":\"ldorqprjevueyzg\",\"value\":\"datassog\"}],\"\":{\"eoma\":\"datavfvirgbguewtcq\",\"ojmxbyviykwrffxo\":\"datanwsgauwe\",\"cxpzje\":\"datawx\",\"npuquyatvsnkrxh\":\"dataoyqlcvtdyuozmtsj\"}}")
+ "{\"type\":\"DatabricksSparkJar\",\"typeProperties\":{\"mainClassName\":\"dataaquiuzsnjjgnmpuq\",\"parameters\":[\"datavdaj\",\"dataczlvcxmtwtbr\"],\"libraries\":[{\"lszcwomayr\":\"datagkxzxwjzleeup\"},{\"fxnxtiwinn\":\"datatrjpar\",\"zgmfnpeluvxs\":\"dataowihsgt\"}]},\"linkedServiceName\":{\"referenceName\":\"p\",\"parameters\":{\"fjjg\":\"dataupngorwvayrgu\",\"fwgrubofhkbjgx\":\"dataf\"}},\"policy\":{\"timeout\":\"datapxjnrujdskkkzqla\",\"retry\":\"databsjirhaqedfua\",\"retryIntervalInSeconds\":1077893342,\"secureInput\":true,\"secureOutput\":true,\"\":{\"hjvmjfrp\":\"datapc\",\"gff\":\"datadxsjceyye\",\"ksmxvevudywnyuy\":\"datantrbnvwhqctqdyfu\"}},\"name\":\"naynlxwukpqcf\",\"description\":\"agtiyvdsl\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"zmzbaqrxz\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Failed\",\"Completed\"],\"\":{\"qwhuepyrfjzyin\":\"dataykekbd\",\"sqk\":\"datauuabe\",\"hryrifhuya\":\"datatb\",\"nfakcchcnmzvhdu\":\"datahesqnvsqteprs\"}}],\"userProperties\":[{\"name\":\"adpqp\",\"value\":\"datahgvwggy\"},{\"name\":\"bmfrxofxuys\",\"value\":\"datawvdqzfgd\"},{\"name\":\"yrppsowdo\",\"value\":\"dataiotgfitbpaircn\"},{\"name\":\"pmzpitziejoebz\",\"value\":\"datafmmce\"}],\"\":{\"kpqnpdlcyjse\":\"datafhjrsxrmlxszx\",\"umlfdxetqknzev\":\"datadfhnhbktobeonl\"}}")
.toObject(DatabricksSparkJarActivity.class);
- Assertions.assertEquals("qf", model.name());
- Assertions.assertEquals("xthcdzeuck", model.description());
+ Assertions.assertEquals("naynlxwukpqcf", model.name());
+ Assertions.assertEquals("agtiyvdsl", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("nikoybr", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("oycg", model.userProperties().get(0).name());
- Assertions.assertEquals("tokipndek", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1180067892, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("zmzbaqrxz", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("adpqp", model.userProperties().get(0).name());
+ Assertions.assertEquals("p", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1077893342, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DatabricksSparkJarActivity model = new DatabricksSparkJarActivity().withName("qf")
- .withDescription("xthcdzeuck")
+ DatabricksSparkJarActivity model = new DatabricksSparkJarActivity().withName("naynlxwukpqcf")
+ .withDescription("agtiyvdsl")
.withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("nikoybr")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wzuj")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("lldeksgejmpkqtj")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED,
- DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("m")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("oycg").withValue("datakik"),
- new UserProperty().withName("q").withValue("datadiihmpmfa"),
- new UserProperty().withName("inodekp").withValue("datacpwcxfnuysrvxaym"),
- new UserProperty().withName("ldorqprjevueyzg").withValue("datassog")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tokipndek")
- .withParameters(mapOf("rotnvxyeqdin", "datadrkddzkki", "xlpgrvtzj", "dataqsejtqoxeth")))
- .withPolicy(new ActivityPolicy().withTimeout("datasrejqwylh")
- .withRetry("datamho")
- .withRetryIntervalInSeconds(1180067892)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("zmzbaqrxz")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED,
+ DependencyCondition.FAILED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("adpqp").withValue("datahgvwggy"),
+ new UserProperty().withName("bmfrxofxuys").withValue("datawvdqzfgd"),
+ new UserProperty().withName("yrppsowdo").withValue("dataiotgfitbpaircn"),
+ new UserProperty().withName("pmzpitziejoebz").withValue("datafmmce")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("p")
+ .withParameters(mapOf("fjjg", "dataupngorwvayrgu", "fwgrubofhkbjgx", "dataf")))
+ .withPolicy(new ActivityPolicy().withTimeout("datapxjnrujdskkkzqla")
+ .withRetry("databsjirhaqedfua")
+ .withRetryIntervalInSeconds(1077893342)
.withSecureInput(true)
- .withSecureOutput(false)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withMainClassName("databtymhh")
- .withParameters(Arrays.asList("datacmwix", "datarvrpujb"))
- .withLibraries(Arrays.asList(mapOf("gteihmvxupqfaww", "datay", "snynvgf", "dataxqjhmfyvgmdwv")));
+ .withMainClassName("dataaquiuzsnjjgnmpuq")
+ .withParameters(Arrays.asList("datavdaj", "dataczlvcxmtwtbr"))
+ .withLibraries(Arrays.asList(mapOf("lszcwomayr", "datagkxzxwjzleeup"),
+ mapOf("fxnxtiwinn", "datatrjpar", "zgmfnpeluvxs", "dataowihsgt")));
model = BinaryData.fromObject(model).toObject(DatabricksSparkJarActivity.class);
- Assertions.assertEquals("qf", model.name());
- Assertions.assertEquals("xthcdzeuck", model.description());
+ Assertions.assertEquals("naynlxwukpqcf", model.name());
+ Assertions.assertEquals("agtiyvdsl", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("nikoybr", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("oycg", model.userProperties().get(0).name());
- Assertions.assertEquals("tokipndek", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1180067892, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("zmzbaqrxz", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("adpqp", model.userProperties().get(0).name());
+ Assertions.assertEquals("p", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1077893342, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTypePropertiesTests.java
index 9020a3c9828f..0b379f7e3ef9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkJarActivityTypePropertiesTests.java
@@ -14,20 +14,17 @@ public final class DatabricksSparkJarActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DatabricksSparkJarActivityTypeProperties model = BinaryData.fromString(
- "{\"mainClassName\":\"dataegwvblrgrzlrnuy\",\"parameters\":[\"datatjzid\"],\"libraries\":[{\"ukjywgsyidqlghr\":\"dataauwhfhynholojcay\",\"nk\":\"datactvl\",\"ejhtbqzxqidguaw\":\"datadrfekxv\",\"uyricaik\":\"datawjbante\"},{\"tfpo\":\"dataj\",\"q\":\"dataalrrqjioltdlppyk\"},{\"ordnwtucvbviymv\":\"datarvghvfodrqmcgeqy\",\"fnvdorsgcvgknbmp\":\"datanq\"}]}")
+ "{\"mainClassName\":\"datay\",\"parameters\":[\"dataqneoezcrmngaq\",\"datainl\"],\"libraries\":[{\"xtkmdegmi\":\"dataxduxcto\"},{\"lpctlbuobi\":\"datau\"},{\"rkmktcs\":\"databt\"}]}")
.toObject(DatabricksSparkJarActivityTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DatabricksSparkJarActivityTypeProperties model
- = new DatabricksSparkJarActivityTypeProperties().withMainClassName("dataegwvblrgrzlrnuy")
- .withParameters(Arrays.asList("datatjzid"))
- .withLibraries(Arrays.asList(
- mapOf("ukjywgsyidqlghr", "dataauwhfhynholojcay", "nk", "datactvl", "ejhtbqzxqidguaw", "datadrfekxv",
- "uyricaik", "datawjbante"),
- mapOf("tfpo", "dataj", "q", "dataalrrqjioltdlppyk"),
- mapOf("ordnwtucvbviymv", "datarvghvfodrqmcgeqy", "fnvdorsgcvgknbmp", "datanq")));
+ = new DatabricksSparkJarActivityTypeProperties().withMainClassName("datay")
+ .withParameters(Arrays.asList("dataqneoezcrmngaq", "datainl"))
+ .withLibraries(Arrays.asList(mapOf("xtkmdegmi", "dataxduxcto"), mapOf("lpctlbuobi", "datau"),
+ mapOf("rkmktcs", "databt")));
model = BinaryData.fromObject(model).toObject(DatabricksSparkJarActivityTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTests.java
index 7e9eefee8093..e0d0fe019538 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTests.java
@@ -22,67 +22,71 @@ public final class DatabricksSparkPythonActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DatabricksSparkPythonActivity model = BinaryData.fromString(
- "{\"type\":\"DatabricksSparkPython\",\"typeProperties\":{\"pythonFile\":\"datanezdp\",\"parameters\":[\"dataqhbbzfcjmhpobu\",\"datapdyztqpszbtbx\",\"datambyltd\",\"dataraxehxotizvwiha\"],\"libraries\":[{\"veb\":\"datafovjiyl\"},{\"a\":\"datavbzsmgeyok\",\"ebgaaxffttfqlcxy\":\"dataehxs\",\"sq\":\"datacmogfbweuazxts\"}]},\"linkedServiceName\":{\"referenceName\":\"dsb\",\"parameters\":{\"bumpplbcarcyrftc\":\"datamwnicdgim\",\"hdlrfyonnb\":\"dataxzmxww\",\"zodolehchimzrc\":\"datavxrcmrdmyjcou\",\"obuanybfm\":\"datazirkyxhqwoxm\"}},\"policy\":{\"timeout\":\"datahpqnzpf\",\"retry\":\"datappkqufdmgmfyia\",\"retryIntervalInSeconds\":410855130,\"secureInput\":true,\"secureOutput\":true,\"\":{\"knygzdrdicwm\":\"datalhyfxmrqpi\",\"hjvvrrxclf\":\"dataeavawywofgccj\"}},\"name\":\"mx\",\"description\":\"qwyiuhhuftnuigx\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"hwxossokafy\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Skipped\",\"Failed\"],\"\":{\"rcsyjxdwvdklgwo\":\"dataijgjbevt\",\"syaohizfysanrbup\":\"datawalefmenbajzeelb\",\"y\":\"datatkddohxvcsoq\",\"danufiwtkhcmoc\":\"datacqpmywt\"}},{\"activity\":\"gtmfug\",\"dependencyConditions\":[\"Skipped\",\"Skipped\"],\"\":{\"dcrdveccmqenfgba\":\"datastkkztexdsnmh\",\"denv\":\"datauuyt\"}},{\"activity\":\"olfiigox\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Succeeded\"],\"\":{\"cfayllx\":\"dataisyydoymccw\",\"tsmyfgted\":\"datahqvmilpgxeaqwogp\",\"dkypckhqooqni\":\"datamcoruti\"}}],\"userProperties\":[{\"name\":\"qsudtmkmgc\",\"value\":\"datapv\"},{\"name\":\"kngvpsukkk\",\"value\":\"datakghugfdugqhmo\"},{\"name\":\"ekoxylcbp\",\"value\":\"datatjtiidozfrgvqurr\"}],\"\":{\"oiikr\":\"datajdrsvohjg\",\"ja\":\"datalzsgpoiccbzqko\",\"zkq\":\"datadm\",\"tazqsucttp\":\"datalz\"}}")
+ "{\"type\":\"DatabricksSparkPython\",\"typeProperties\":{\"pythonFile\":\"dataktg\",\"parameters\":[\"datazzsohcaet\",\"dataepmhohq\",\"datalk\",\"dataatliwoodndub\"],\"libraries\":[{\"zdttgbsdaruwvrvx\":\"datazirgiyqzuhnb\",\"adeqslhz\":\"dataozyhu\",\"mqazolroqusrlkp\":\"datay\"},{\"ae\":\"datayqydrnws\"},{\"gzjmjdoqitfd\":\"databpdpkdlhuslqiko\"}]},\"linkedServiceName\":{\"referenceName\":\"ekbb\",\"parameters\":{\"zhrwpjtj\":\"dataoxddgjdpyhem\",\"gaiusglg\":\"datapoynbsttureqvxzl\",\"swmkxbbziffpvvg\":\"dataecsreo\"}},\"policy\":{\"timeout\":\"datamghe\",\"retry\":\"datamoetygevy\",\"retryIntervalInSeconds\":1499181439,\"secureInput\":false,\"secureOutput\":true,\"\":{\"mr\":\"datayjqklaihqrb\",\"tpydjsubtifb\":\"dataljqqbu\",\"jguwdfn\":\"datacveomdlr\"}},\"name\":\"qvuq\",\"description\":\"aowuib\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ynlvovjslxe\",\"dependencyConditions\":[\"Failed\"],\"\":{\"gzlrnfmme\":\"datahjawmrhp\",\"d\":\"datappjxtgffwq\",\"t\":\"datagfgirrzyngdvdr\",\"kqaqfbimfpnpmkdg\":\"dataqfrxggvstyxv\"}},{\"activity\":\"ndwtdorvxdwgpu\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Completed\"],\"\":{\"dzjmjkg\":\"datadwqr\",\"as\":\"dataupplcoqbouetfxza\"}},{\"activity\":\"dlokhimzfltxqpoz\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"jwjnvhu\":\"datakfevhgjk\"}},{\"activity\":\"wmwvqbpazjmfqu\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Skipped\",\"Failed\"],\"\":{\"hdyifjvfrg\":\"datagjaa\",\"cwpjpkaf\":\"datanquj\",\"vuyc\":\"datakaf\",\"qsmk\":\"datatlmnrdkiqsqbdvk\"}}],\"userProperties\":[{\"name\":\"ljxnkpd\",\"value\":\"datamexrofqh\"},{\"name\":\"ptsdlcsrhttmh\",\"value\":\"datagwov\"},{\"name\":\"duzqu\",\"value\":\"datakrcwnlyqq\"},{\"name\":\"knul\",\"value\":\"dataq\"}],\"\":{\"euifndgrjnzjyghq\":\"datausmosjawbnxci\",\"ln\":\"datafs\",\"ems\":\"datavgec\"}}")
.toObject(DatabricksSparkPythonActivity.class);
- Assertions.assertEquals("mx", model.name());
- Assertions.assertEquals("qwyiuhhuftnuigx", model.description());
+ Assertions.assertEquals("qvuq", model.name());
+ Assertions.assertEquals("aowuib", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("hwxossokafy", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("qsudtmkmgc", model.userProperties().get(0).name());
- Assertions.assertEquals("dsb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(410855130, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals("ynlvovjslxe", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("ljxnkpd", model.userProperties().get(0).name());
+ Assertions.assertEquals("ekbb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1499181439, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DatabricksSparkPythonActivity model = new DatabricksSparkPythonActivity().withName("mx")
- .withDescription("qwyiuhhuftnuigx")
+ DatabricksSparkPythonActivity model = new DatabricksSparkPythonActivity().withName("qvuq")
+ .withDescription("aowuib")
.withState(ActivityState.ACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("hwxossokafy")
+ new ActivityDependency().withActivity("ynlvovjslxe")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ndwtdorvxdwgpu")
.withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED, DependencyCondition.FAILED))
+ DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("gtmfug")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
+ new ActivityDependency().withActivity("dlokhimzfltxqpoz")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("olfiigox")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("wmwvqbpazjmfqu")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.COMPLETED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("qsudtmkmgc").withValue("datapv"),
- new UserProperty().withName("kngvpsukkk").withValue("datakghugfdugqhmo"),
- new UserProperty().withName("ekoxylcbp").withValue("datatjtiidozfrgvqurr")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dsb")
- .withParameters(mapOf("bumpplbcarcyrftc", "datamwnicdgim", "hdlrfyonnb", "dataxzmxww", "zodolehchimzrc",
- "datavxrcmrdmyjcou", "obuanybfm", "datazirkyxhqwoxm")))
- .withPolicy(new ActivityPolicy().withTimeout("datahpqnzpf")
- .withRetry("datappkqufdmgmfyia")
- .withRetryIntervalInSeconds(410855130)
- .withSecureInput(true)
+ .withUserProperties(Arrays.asList(new UserProperty().withName("ljxnkpd").withValue("datamexrofqh"),
+ new UserProperty().withName("ptsdlcsrhttmh").withValue("datagwov"),
+ new UserProperty().withName("duzqu").withValue("datakrcwnlyqq"),
+ new UserProperty().withName("knul").withValue("dataq")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ekbb")
+ .withParameters(mapOf("zhrwpjtj", "dataoxddgjdpyhem", "gaiusglg", "datapoynbsttureqvxzl",
+ "swmkxbbziffpvvg", "dataecsreo")))
+ .withPolicy(new ActivityPolicy().withTimeout("datamghe")
+ .withRetry("datamoetygevy")
+ .withRetryIntervalInSeconds(1499181439)
+ .withSecureInput(false)
.withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withPythonFile("datanezdp")
- .withParameters(
- Arrays.asList("dataqhbbzfcjmhpobu", "datapdyztqpszbtbx", "datambyltd", "dataraxehxotizvwiha"))
- .withLibraries(Arrays.asList(mapOf("veb", "datafovjiyl"),
- mapOf("a", "datavbzsmgeyok", "ebgaaxffttfqlcxy", "dataehxs", "sq", "datacmogfbweuazxts")));
+ .withPythonFile("dataktg")
+ .withParameters(Arrays.asList("datazzsohcaet", "dataepmhohq", "datalk", "dataatliwoodndub"))
+ .withLibraries(Arrays.asList(
+ mapOf("zdttgbsdaruwvrvx", "datazirgiyqzuhnb", "adeqslhz", "dataozyhu", "mqazolroqusrlkp", "datay"),
+ mapOf("ae", "datayqydrnws"), mapOf("gzjmjdoqitfd", "databpdpkdlhuslqiko")));
model = BinaryData.fromObject(model).toObject(DatabricksSparkPythonActivity.class);
- Assertions.assertEquals("mx", model.name());
- Assertions.assertEquals("qwyiuhhuftnuigx", model.description());
+ Assertions.assertEquals("qvuq", model.name());
+ Assertions.assertEquals("aowuib", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("hwxossokafy", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("qsudtmkmgc", model.userProperties().get(0).name());
- Assertions.assertEquals("dsb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(410855130, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals("ynlvovjslxe", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("ljxnkpd", model.userProperties().get(0).name());
+ Assertions.assertEquals("ekbb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1499181439, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTypePropertiesTests.java
index 61d370e6354e..1548250f34d6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatabricksSparkPythonActivityTypePropertiesTests.java
@@ -14,17 +14,17 @@ public final class DatabricksSparkPythonActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DatabricksSparkPythonActivityTypeProperties model = BinaryData.fromString(
- "{\"pythonFile\":\"datatwgbfiosdizpg\",\"parameters\":[\"dataglzfgepblhe\"],\"libraries\":[{\"amrytrny\":\"datavenmuenoq\",\"mbj\":\"dataoixiduzrdvhgyj\",\"g\":\"datafwlxkxlru\"}]}")
+ "{\"pythonFile\":\"datacgrkgt\",\"parameters\":[\"datalaywkbuved\",\"datatezeyfdgnaoi\",\"datarufdgtwxie\"],\"libraries\":[{\"eeqelmrp\":\"datagphfzdgs\",\"rgqskd\":\"datagg\",\"vgodekfefae\":\"datajwobegdxjxk\",\"jrakn\":\"dataulrfeqefqdvoo\"}]}")
.toObject(DatabricksSparkPythonActivityTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DatabricksSparkPythonActivityTypeProperties model = new DatabricksSparkPythonActivityTypeProperties()
- .withPythonFile("datatwgbfiosdizpg")
- .withParameters(Arrays.asList("dataglzfgepblhe"))
- .withLibraries(
- Arrays.asList(mapOf("amrytrny", "datavenmuenoq", "mbj", "dataoixiduzrdvhgyj", "g", "datafwlxkxlru")));
+ DatabricksSparkPythonActivityTypeProperties model
+ = new DatabricksSparkPythonActivityTypeProperties().withPythonFile("datacgrkgt")
+ .withParameters(Arrays.asList("datalaywkbuved", "datatezeyfdgnaoi", "datarufdgtwxie"))
+ .withLibraries(Arrays.asList(mapOf("eeqelmrp", "datagphfzdgs", "rgqskd", "datagg", "vgodekfefae",
+ "datajwobegdxjxk", "jrakn", "dataulrfeqefqdvoo")));
model = BinaryData.fromObject(model).toObject(DatabricksSparkPythonActivityTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsCreateOrUpdateWithResponseMockTests.java
index d9fe53dc06ff..e931bdc122a6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsCreateOrUpdateWithResponseMockTests.java
@@ -29,7 +29,7 @@ public final class DatasetsCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"Dataset\",\"description\":\"nevbkkdbhgu\",\"structure\":\"dataxqi\",\"schema\":\"datarj\",\"linkedServiceName\":{\"referenceName\":\"lieyyfqhndj\",\"parameters\":{\"fhsgpy\":\"datavuyxccraj\"}},\"parameters\":{\"nrlpsjbnnuqsz\":{\"type\":\"Int\",\"defaultValue\":\"datad\"},\"dbunxufataq\":{\"type\":\"Array\",\"defaultValue\":\"dataiufrqsmjg\"},\"unazl\":{\"type\":\"Array\",\"defaultValue\":\"datahgdwhacurmm\"},\"isuhareqyiadvv\":{\"type\":\"String\",\"defaultValue\":\"datanyzcnq\"}},\"annotations\":[\"datafyel\",\"datan\",\"datapnyyuxcjq\"],\"folder\":{\"name\":\"sdntuko\"},\"\":{\"ygecly\":\"dataflfv\",\"jbzd\":\"datatoshkzib\"}},\"name\":\"gpv\",\"type\":\"icw\",\"etag\":\"y\",\"id\":\"hglltjghdfus\"}";
+ = "{\"properties\":{\"type\":\"Dataset\",\"description\":\"yqgvofhpguj\",\"structure\":\"datakwwyfsq\",\"schema\":\"datass\",\"linkedServiceName\":{\"referenceName\":\"cxazvrmu\",\"parameters\":{\"bruszqmud\":\"dataegohpwnrmhlotk\",\"lowesixpwfvtwgn\":\"dataefsxmd\"}},\"parameters\":{\"hcjhinjnwpi\":{\"type\":\"Bool\",\"defaultValue\":\"dataxwkomjsfkdv\"}},\"annotations\":[\"datalbajqecngw\",\"datazuaxsrmadakj\"],\"folder\":{\"name\":\"uv\"},\"\":{\"hotwq\":\"databkkekldxclqjn\",\"utmsmdibzvytem\":\"datagvrzlimz\",\"kcxuvdcwtnz\":\"datasa\"}},\"name\":\"eghn\",\"type\":\"wjwwhsfjqxlbclvp\",\"etag\":\"utyrsravsscb\",\"id\":\"xmscafgdtuzcl\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -39,28 +39,29 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
DatasetResource response = manager.datasets()
- .define("wc")
- .withExistingFactory("cnwqeixyjlfobj", "betsvnloduvcq")
- .withProperties(new Dataset().withDescription("feolhs")
- .withStructure("datakivlzvxmqvl")
- .withSchema("datappnsiynz")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("adkurwg")
- .withParameters(mapOf("llcsdgmcjsktej", "datanjox", "ezzpfldd", "datamhttiqbnfyixkeav", "xrfr",
- "datavcwhodfwv")))
- .withParameters(
- mapOf("ofgpns", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datat"),
- "w", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datase")))
- .withAnnotations(Arrays.asList("datafpoqbekkqsaby"))
- .withFolder(new DatasetFolder().withName("rwprbzfbdsncy"))
+ .define("gdgfjvitdp")
+ .withExistingFactory("iv", "ftjjmtk")
+ .withProperties(new Dataset().withDescription("oesx")
+ .withStructure("datavslhncasp")
+ .withSchema("dataglaxvn")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qhatwxq")
+ .withParameters(mapOf("huudtiecnpka", "databirzjhaicyuplm", "osrywpfcqle", "datatjqjtoeaug")))
+ .withParameters(mapOf("colwquxrrjud",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataizdecgiom"),
+ "twfmvpsvwwtncvn",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datahgsd"), "icovvd",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datagnl")))
+ .withAnnotations(Arrays.asList("datafnbdpaoijx", "datagfmftrv"))
+ .withFolder(new DatasetFolder().withName("jfkpuszsjayrl"))
.withAdditionalProperties(mapOf("type", "Dataset")))
- .withIfMatch("tbwe")
+ .withIfMatch("zipzkkleazkc")
.create();
- Assertions.assertEquals("hglltjghdfus", response.id());
- Assertions.assertEquals("nevbkkdbhgu", response.properties().description());
- Assertions.assertEquals("lieyyfqhndj", response.properties().linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, response.properties().parameters().get("nrlpsjbnnuqsz").type());
- Assertions.assertEquals("sdntuko", response.properties().folder().name());
+ Assertions.assertEquals("xmscafgdtuzcl", response.id());
+ Assertions.assertEquals("yqgvofhpguj", response.properties().description());
+ Assertions.assertEquals("cxazvrmu", response.properties().linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, response.properties().parameters().get("hcjhinjnwpi").type());
+ Assertions.assertEquals("uv", response.properties().folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsDeleteWithResponseMockTests.java
index 2338fabcb22e..b8276e632b1d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsDeleteWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.datasets()
- .deleteWithResponse("ypouvpdclajujsov", "freyrgrgf", "zehxddmaevcjtrw", com.azure.core.util.Context.NONE);
+ .deleteWithResponse("sjboiyqixb", "jhvkttusyxz", "vfwyoqjtt", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsGetWithResponseMockTests.java
index 8f61a587c4a8..2cee64a765cf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsGetWithResponseMockTests.java
@@ -22,7 +22,7 @@ public final class DatasetsGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"Dataset\",\"description\":\"dnxwkf\",\"structure\":\"dataursbyfoavozqn\",\"schema\":\"datamxitvmrq\",\"linkedServiceName\":{\"referenceName\":\"kzchcmuvskdvqyf\",\"parameters\":{\"f\":\"dataxca\",\"yohzhu\":\"datavjpfojhvqmdo\",\"k\":\"datad\",\"pgarhf\":\"datadxfvjdfusuwght\"}},\"parameters\":{\"vqpmwqsd\":{\"type\":\"String\",\"defaultValue\":\"dataivadpc\"}},\"annotations\":[\"datae\",\"datakfsgrheakvl\",\"dataukmnu\"],\"folder\":{\"name\":\"bjclihfzrii\"},\"\":{\"nctkqbvtdeou\":\"dataqyptmjqjoamzdsa\",\"juwdvfaulbfrc\":\"dataixgtpykbjevj\"}},\"name\":\"ucobpkphxh\",\"type\":\"fekxbcbumj\",\"etag\":\"ukezqohthsmdua\",\"id\":\"pryuw\"}";
+ = "{\"properties\":{\"type\":\"Dataset\",\"description\":\"tya\",\"structure\":\"datacznotggyg\",\"schema\":\"datasghafzdzdf\",\"linkedServiceName\":{\"referenceName\":\"udmiutzuriqlksba\",\"parameters\":{\"qzdxdal\":\"datatiqzjrxhelqh\"}},\"parameters\":{\"eipxdn\":{\"type\":\"Float\",\"defaultValue\":\"dataymdywjzqm\"},\"rdxquowe\":{\"type\":\"Int\",\"defaultValue\":\"dataxhpxsbhua\"}},\"annotations\":[\"dataxzduydnvvwoclmdc\",\"dataqwdme\"],\"folder\":{\"name\":\"jeuguvnwcvlmy\"},\"\":{\"mptxmuejlseumm\":\"datawrtub\",\"dmfrjqfem\":\"datapq\",\"vfyjvkmompwtevqb\":\"datadkxipr\"}},\"name\":\"jlnnvhbejutupgm\",\"type\":\"ityp\",\"etag\":\"qakpbkwqavxlja\",\"id\":\"gxxmxdrgxhrta\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,13 +32,13 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
DatasetResource response = manager.datasets()
- .getWithResponse("uhjxvcjrxle", "yptvrbgcp", "sd", "swozpm", com.azure.core.util.Context.NONE)
+ .getWithResponse("tc", "cdomzfw", "jt", "ox", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("pryuw", response.id());
- Assertions.assertEquals("dnxwkf", response.properties().description());
- Assertions.assertEquals("kzchcmuvskdvqyf", response.properties().linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, response.properties().parameters().get("vqpmwqsd").type());
- Assertions.assertEquals("bjclihfzrii", response.properties().folder().name());
+ Assertions.assertEquals("gxxmxdrgxhrta", response.id());
+ Assertions.assertEquals("tya", response.properties().description());
+ Assertions.assertEquals("udmiutzuriqlksba", response.properties().linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, response.properties().parameters().get("eipxdn").type());
+ Assertions.assertEquals("jeuguvnwcvlmy", response.properties().folder().name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsListByFactoryMockTests.java
index 734d41962526..1d6e7dd8ac9a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DatasetsListByFactoryMockTests.java
@@ -23,7 +23,7 @@ public final class DatasetsListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"type\":\"Dataset\",\"description\":\"zflydywbn\",\"structure\":\"dataygsifsahkc\",\"schema\":\"datavajnsu\",\"linkedServiceName\":{\"referenceName\":\"xbyrvguojkysol\",\"parameters\":{\"qfhnqxqtemvqxxuw\":\"datafhlynkiusbyysbjt\",\"ylkdbyo\":\"dataatuiqc\"}},\"parameters\":{\"imtouclsabjzh\":{\"type\":\"Bool\",\"defaultValue\":\"dataavppos\"},\"bhnuujk\":{\"type\":\"String\",\"defaultValue\":\"datavuvjs\"},\"thduactizzhln\":{\"type\":\"Bool\",\"defaultValue\":\"datayewtlomagxaqvra\"},\"djdptruiegrauy\":{\"type\":\"SecureString\",\"defaultValue\":\"datagqciiopoamgheamx\"}},\"annotations\":[\"datagwauipatodfyrf\",\"datapmcjrfj\",\"dataisypkif\",\"datatynhulefltub\"],\"folder\":{\"name\":\"bbl\"},\"\":{\"hfoephiphoygmc\":\"dataahrdxytk\",\"oukimvhqis\":\"dataq\",\"cf\":\"datavologfxbvl\"}},\"name\":\"ajncefqnhr\",\"type\":\"mu\",\"etag\":\"de\",\"id\":\"uohtnjtahdtdc\"}]}";
+ = "{\"value\":[{\"properties\":{\"type\":\"Dataset\",\"description\":\"bxtabxdkboyqes\",\"structure\":\"datacvutarurfjp\",\"schema\":\"datailuikqzdqk\",\"linkedServiceName\":{\"referenceName\":\"jcqdnzhjlb\",\"parameters\":{\"ikxocfmkcnjzxezo\":\"datankvipjin\",\"tewthslzt\":\"datar\",\"weuxycbvefldfw\":\"dataixn\",\"znlscfbwkh\":\"datanbc\"}},\"parameters\":{\"oq\":{\"type\":\"String\",\"defaultValue\":\"databoprgxdcnbzpc\"},\"pdvnanxrkwzlaomt\":{\"type\":\"Array\",\"defaultValue\":\"datapzekm\"}},\"annotations\":[\"datattmhsrwqp\",\"dataxyfjeibcge\",\"dataipoequjkhu\"],\"folder\":{\"name\":\"xxcbptvvwfamhlj\"},\"\":{\"bczwd\":\"datamhccwmrckv\",\"ohxmzpfptt\":\"dataydbsrjofxoktokms\"}},\"name\":\"wqrbtadsdkbndkof\",\"type\":\"uycnayhodtugrwp\",\"etag\":\"fkgzgveud\",\"id\":\"dtnsqt\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -33,14 +33,14 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.datasets().listByFactory("zxtrjruwljfdcy", "p", com.azure.core.util.Context.NONE);
+ = manager.datasets().listByFactory("faagpjslrf", "xlutfbhsenn", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("uohtnjtahdtdc", response.iterator().next().id());
- Assertions.assertEquals("zflydywbn", response.iterator().next().properties().description());
- Assertions.assertEquals("xbyrvguojkysol",
+ Assertions.assertEquals("dtnsqt", response.iterator().next().id());
+ Assertions.assertEquals("bxtabxdkboyqes", response.iterator().next().properties().description());
+ Assertions.assertEquals("jcqdnzhjlb",
response.iterator().next().properties().linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL,
- response.iterator().next().properties().parameters().get("imtouclsabjzh").type());
- Assertions.assertEquals("bbl", response.iterator().next().properties().folder().name());
+ Assertions.assertEquals(ParameterType.STRING,
+ response.iterator().next().properties().parameters().get("oq").type());
+ Assertions.assertEquals("xxcbptvvwfamhlj", response.iterator().next().properties().folder().name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2SourceTests.java
index 36b88e239354..2b5c7065c823 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2SourceTests.java
@@ -11,19 +11,19 @@ public final class Db2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
Db2Source model = BinaryData.fromString(
- "{\"type\":\"Db2Source\",\"query\":\"databjclfb\",\"queryTimeout\":\"datadsatrz\",\"additionalColumns\":\"datatuxwtdaz\",\"sourceRetryCount\":\"dataifktnxugi\",\"sourceRetryWait\":\"databwyeyrnbuby\",\"maxConcurrentConnections\":\"datatowbuuhlwbgvzuxf\",\"disableMetricsCollection\":\"datafpdzuoqp\",\"\":{\"pljzrqwjtswemot\":\"datavnoylmfjylh\"}}")
+ "{\"type\":\"Db2Source\",\"query\":\"dataqyllcckgfo\",\"queryTimeout\":\"datarbfyjmenq\",\"additionalColumns\":\"datajfxqtvsfsvqy\",\"sourceRetryCount\":\"dataaweixnoblazwhda\",\"sourceRetryWait\":\"dataixfdu\",\"maxConcurrentConnections\":\"datas\",\"disableMetricsCollection\":\"dataitpcsmax\",\"\":{\"a\":\"dataubhmiuxypvua\"}}")
.toObject(Db2Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- Db2Source model = new Db2Source().withSourceRetryCount("dataifktnxugi")
- .withSourceRetryWait("databwyeyrnbuby")
- .withMaxConcurrentConnections("datatowbuuhlwbgvzuxf")
- .withDisableMetricsCollection("datafpdzuoqp")
- .withQueryTimeout("datadsatrz")
- .withAdditionalColumns("datatuxwtdaz")
- .withQuery("databjclfb");
+ Db2Source model = new Db2Source().withSourceRetryCount("dataaweixnoblazwhda")
+ .withSourceRetryWait("dataixfdu")
+ .withMaxConcurrentConnections("datas")
+ .withDisableMetricsCollection("dataitpcsmax")
+ .withQueryTimeout("datarbfyjmenq")
+ .withAdditionalColumns("datajfxqtvsfsvqy")
+ .withQuery("dataqyllcckgfo");
model = BinaryData.fromObject(model).toObject(Db2Source.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTests.java
index d29981c35d0a..7f5d46d8e535 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTests.java
@@ -19,33 +19,35 @@ public final class Db2TableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
Db2TableDataset model = BinaryData.fromString(
- "{\"type\":\"Db2Table\",\"typeProperties\":{\"tableName\":\"datarsvxphtjnhptj\",\"schema\":\"datak\",\"table\":\"datayzhimm\"},\"description\":\"tdtftmizuzjd\",\"structure\":\"datagyzcslazprkq\",\"schema\":\"dataimxpggktteagb\",\"linkedServiceName\":{\"referenceName\":\"acnq\",\"parameters\":{\"eylpby\":\"dataytvu\"}},\"parameters\":{\"glpwdjr\":{\"type\":\"Array\",\"defaultValue\":\"dataoifm\"}},\"annotations\":[\"datafshznu\",\"datattuhaaax\",\"datadcdjmdkqtxfrmbe\",\"dataxstowagehxuihwes\"],\"folder\":{\"name\":\"aqgblkkncyp\"},\"\":{\"piobnhrfbrjokjwq\":\"datavspsaneyvae\",\"zwfwlrfdjwlzseod\":\"datamraqnilppqcaig\",\"zy\":\"dataqfdrs\"}}")
+ "{\"type\":\"Db2Table\",\"typeProperties\":{\"tableName\":\"datak\",\"schema\":\"dataztirjvqxvwkiocxo\",\"table\":\"datajwbu\"},\"description\":\"qflm\",\"structure\":\"datarlqxbctatez\",\"schema\":\"datazdbcqqnlsjxcsc\",\"linkedServiceName\":{\"referenceName\":\"it\",\"parameters\":{\"t\":\"datarahjjidodnv\"}},\"parameters\":{\"hiclhyzhr\":{\"type\":\"Int\",\"defaultValue\":\"datapuwkupbb\"},\"nhlsforsimtfcqm\":{\"type\":\"SecureString\",\"defaultValue\":\"datafwbif\"}},\"annotations\":[\"databrpelpf\",\"datajt\",\"datazgxmpeszamadle\",\"dataz\"],\"folder\":{\"name\":\"ui\"},\"\":{\"lxswtdapsm\":\"datakt\"}}")
.toObject(Db2TableDataset.class);
- Assertions.assertEquals("tdtftmizuzjd", model.description());
- Assertions.assertEquals("acnq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("glpwdjr").type());
- Assertions.assertEquals("aqgblkkncyp", model.folder().name());
+ Assertions.assertEquals("qflm", model.description());
+ Assertions.assertEquals("it", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("hiclhyzhr").type());
+ Assertions.assertEquals("ui", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- Db2TableDataset model = new Db2TableDataset().withDescription("tdtftmizuzjd")
- .withStructure("datagyzcslazprkq")
- .withSchema("dataimxpggktteagb")
+ Db2TableDataset model = new Db2TableDataset().withDescription("qflm")
+ .withStructure("datarlqxbctatez")
+ .withSchema("datazdbcqqnlsjxcsc")
.withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("acnq").withParameters(mapOf("eylpby", "dataytvu")))
- .withParameters(mapOf("glpwdjr",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataoifm")))
- .withAnnotations(Arrays.asList("datafshznu", "datattuhaaax", "datadcdjmdkqtxfrmbe", "dataxstowagehxuihwes"))
- .withFolder(new DatasetFolder().withName("aqgblkkncyp"))
- .withTableName("datarsvxphtjnhptj")
- .withSchemaTypePropertiesSchema("datak")
- .withTable("datayzhimm");
+ new LinkedServiceReference().withReferenceName("it").withParameters(mapOf("t", "datarahjjidodnv")))
+ .withParameters(mapOf("hiclhyzhr",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datapuwkupbb"),
+ "nhlsforsimtfcqm",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datafwbif")))
+ .withAnnotations(Arrays.asList("databrpelpf", "datajt", "datazgxmpeszamadle", "dataz"))
+ .withFolder(new DatasetFolder().withName("ui"))
+ .withTableName("datak")
+ .withSchemaTypePropertiesSchema("dataztirjvqxvwkiocxo")
+ .withTable("datajwbu");
model = BinaryData.fromObject(model).toObject(Db2TableDataset.class);
- Assertions.assertEquals("tdtftmizuzjd", model.description());
- Assertions.assertEquals("acnq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("glpwdjr").type());
- Assertions.assertEquals("aqgblkkncyp", model.folder().name());
+ Assertions.assertEquals("qflm", model.description());
+ Assertions.assertEquals("it", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("hiclhyzhr").type());
+ Assertions.assertEquals("ui", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTypePropertiesTests.java
index cfdf199dc820..e45a07cfe262 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Db2TableDatasetTypePropertiesTests.java
@@ -10,16 +10,16 @@
public final class Db2TableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- Db2TableDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"dataxserw\",\"schema\":\"datauhytjwgetfi\",\"table\":\"datan\"}")
- .toObject(Db2TableDatasetTypeProperties.class);
+ Db2TableDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"datamnrijefmrtw\",\"schema\":\"dataevdspthgffmwtbl\",\"table\":\"datakok\"}")
+ .toObject(Db2TableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- Db2TableDatasetTypeProperties model = new Db2TableDatasetTypeProperties().withTableName("dataxserw")
- .withSchema("datauhytjwgetfi")
- .withTable("datan");
+ Db2TableDatasetTypeProperties model = new Db2TableDatasetTypeProperties().withTableName("datamnrijefmrtw")
+ .withSchema("dataevdspthgffmwtbl")
+ .withTable("datakok");
model = BinaryData.fromObject(model).toObject(Db2TableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTests.java
index 3032b9cd98c9..68e77061f777 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTests.java
@@ -25,82 +25,91 @@ public final class DeleteActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DeleteActivity model = BinaryData.fromString(
- "{\"type\":\"Delete\",\"typeProperties\":{\"recursive\":\"dataezjyfaqdwfa\",\"maxConcurrentConnections\":540501730,\"enableLogging\":\"dataetslxerhwlvh\",\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"xxgeladqziljrsyc\",\"parameters\":{\"hxpix\":\"datasznjskwjjupu\",\"icufxtcyt\":\"datayyqsonfxsfjedjn\"}},\"path\":\"datasp\",\"logLevel\":\"datauhztvbgcflttes\",\"enableReliableLogging\":\"datajcuuyttuind\",\"\":{\"nsbjzrnjcagagm\":\"dataijncaqgtsbahtlop\",\"nashnoxr\":\"dataul\",\"qzwutakbvaqg\":\"dataabbetzcd\"}},\"dataset\":{\"referenceName\":\"aubmcwpllo\",\"parameters\":{\"tddigmmj\":\"datacdue\"}},\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datajrcrbkw\",\"disableMetricsCollection\":\"datavg\",\"\":{\"jcemkcwcb\":\"dataih\"}}},\"linkedServiceName\":{\"referenceName\":\"qjpi\",\"parameters\":{\"ogfo\":\"datawhrgmzntroafzrq\",\"ojjbky\":\"datarryzbqpksoaxszuh\"}},\"policy\":{\"timeout\":\"datadgvhecqk\",\"retry\":\"datatemamyshnksu\",\"retryIntervalInSeconds\":685032717,\"secureInput\":true,\"secureOutput\":false,\"\":{\"hgchtaeac\":\"datavumxyqhctrrv\"}},\"name\":\"qk\",\"description\":\"zuk\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"qfqawynsl\",\"dependencyConditions\":[\"Failed\"],\"\":{\"iriedfyht\":\"datavav\",\"qc\":\"dataugppiudhyl\"}},{\"activity\":\"umq\",\"dependencyConditions\":[\"Completed\"],\"\":{\"kbchnhexmg\":\"dataxzcrf\",\"wyzvnsnak\":\"dataqlufojuexpkqhg\",\"mltdgxiqrgr\":\"dataobcuy\",\"qyjeeoytgny\":\"dataxjfxu\"}},{\"activity\":\"nklqi\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Failed\",\"Failed\"],\"\":{\"hx\":\"dataglalaazncnhzq\",\"galodfsbhphwt\":\"datascyykrzrjjernj\",\"ajh\":\"datagy\"}}],\"userProperties\":[{\"name\":\"arldsijcm\",\"value\":\"dataugpxgxjmwzkafuvb\"},{\"name\":\"cyarsbhjlcxvsmr\",\"value\":\"dataypbi\"}],\"\":{\"b\":\"dataznaixjsfasxfamn\",\"wco\":\"dataxbglqybfnxej\",\"cnuozjg\":\"datajmpsxot\",\"gnrrqvrxouoqte\":\"datacxbenwi\"}}")
+ "{\"type\":\"Delete\",\"typeProperties\":{\"recursive\":\"datararzk\",\"maxConcurrentConnections\":1386173284,\"enableLogging\":\"datanvye\",\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"dvzomtzp\",\"parameters\":{\"twzesejdcpcpeu\":\"dataxgslzbpnlfzqwmxu\",\"jrptltytbqhejhn\":\"databofzmvtwyjc\",\"meeuuurx\":\"datajlbygq\",\"ob\":\"dataslxzwvygquiwcfq\"}},\"path\":\"datawdevq\",\"logLevel\":\"dataejhvggykirqkskyy\",\"enableReliableLogging\":\"datammim\",\"\":{\"qjb\":\"datawcd\",\"lvlfkwdtsbjmc\":\"datarxmlmibvczdjko\"}},\"dataset\":{\"referenceName\":\"sefezjyfaqdwfa\",\"parameters\":{\"hwlvh\":\"datadetslxe\",\"zil\":\"datalxxgelad\",\"jjupukhxpixuyy\":\"datarsycujnsznjsk\"}},\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datanfxsfjed\",\"disableMetricsCollection\":\"dataxicufxtcyteds\",\"\":{\"pjc\":\"datauhztvbgcflttes\",\"aqgtsbaht\":\"datauyttuindpmrijn\",\"mgulln\":\"dataopbnsbjzrnjcaga\",\"tzcdbqzwutakbva\":\"datashnoxrmabb\"}}},\"linkedServiceName\":{\"referenceName\":\"uaubmcwpll\",\"parameters\":{\"ewtddigmmjve\":\"dataccd\",\"nvgxg\":\"datajrcrbkw\",\"jcemkcwcb\":\"dataih\"}},\"policy\":{\"timeout\":\"datajpiafzwhrgmznt\",\"retry\":\"dataafzrqmogfojrryz\",\"retryIntervalInSeconds\":543157036,\"secureInput\":false,\"secureOutput\":false,\"\":{\"hecq\":\"datazuhuojjbkyddsdg\",\"shnksupchzspgby\":\"databetemam\",\"vuhgchtaea\":\"dataumxyqhctr\"}},\"name\":\"bqkx\",\"description\":\"ukajk\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"awynslcfx\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"ugppiudhyl\":\"datairiedfyht\",\"umq\":\"dataqc\"}},{\"activity\":\"ri\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Skipped\",\"Skipped\"],\"\":{\"qlufojuexpkqhg\":\"datakbchnhexmg\",\"obcuy\":\"datawyzvnsnak\",\"xjfxu\":\"datamltdgxiqrgr\"}},{\"activity\":\"qyjeeoytgny\",\"dependencyConditions\":[\"Skipped\",\"Skipped\"],\"\":{\"azncnh\":\"datapnzgnybuglal\",\"hx\":\"dataq\",\"galodfsbhphwt\":\"datascyykrzrjjernj\",\"ajh\":\"datagy\"}},{\"activity\":\"txarl\",\"dependencyConditions\":[\"Succeeded\",\"Failed\"],\"\":{\"xjmw\":\"datanugpx\",\"gc\":\"datakafuv\",\"biwnyznaixjsfas\":\"dataarsbhjlcxvsmrxy\",\"nxejxwcojjmp\":\"datafamnpbyxbglqyb\"}}],\"userProperties\":[{\"name\":\"tqc\",\"value\":\"datauozjgkcxb\"},{\"name\":\"nwiignr\",\"value\":\"dataqvrxouoqtestr\"}],\"\":{\"yyzaalpwwcwie\":\"dataskmvr\",\"wqmundle\":\"datasswijqsndqjbdtcz\",\"hrygdp\":\"datadlcuedrmqkwkutbt\",\"tcfppjegctsatnry\":\"dataufmvozq\"}}")
.toObject(DeleteActivity.class);
- Assertions.assertEquals("qk", model.name());
- Assertions.assertEquals("zuk", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("qfqawynsl", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("arldsijcm", model.userProperties().get(0).name());
- Assertions.assertEquals("qjpi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(685032717, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals("bqkx", model.name());
+ Assertions.assertEquals("ukajk", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("awynslcfx", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("tqc", model.userProperties().get(0).name());
+ Assertions.assertEquals("uaubmcwpll", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(543157036, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(540501730, model.maxConcurrentConnections());
- Assertions.assertEquals("xxgeladqziljrsyc", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("aubmcwpllo", model.dataset().referenceName());
+ Assertions.assertEquals(1386173284, model.maxConcurrentConnections());
+ Assertions.assertEquals("dvzomtzp", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("sefezjyfaqdwfa", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DeleteActivity model = new DeleteActivity().withName("qk")
- .withDescription("zuk")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("qfqawynsl")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("umq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("nklqi")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("arldsijcm").withValue("dataugpxgxjmwzkafuvb"),
- new UserProperty().withName("cyarsbhjlcxvsmr").withValue("dataypbi")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qjpi")
- .withParameters(mapOf("ogfo", "datawhrgmzntroafzrq", "ojjbky", "datarryzbqpksoaxszuh")))
- .withPolicy(new ActivityPolicy().withTimeout("datadgvhecqk")
- .withRetry("datatemamyshnksu")
- .withRetryIntervalInSeconds(685032717)
- .withSecureInput(true)
- .withSecureOutput(false)
- .withAdditionalProperties(mapOf()))
- .withRecursive("dataezjyfaqdwfa")
- .withMaxConcurrentConnections(540501730)
- .withEnableLogging("dataetslxerhwlvh")
- .withLogStorageSettings(new LogStorageSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xxgeladqziljrsyc")
- .withParameters(mapOf("hxpix", "datasznjskwjjupu", "icufxtcyt", "datayyqsonfxsfjedjn")))
- .withPath("datasp")
- .withLogLevel("datauhztvbgcflttes")
- .withEnableReliableLogging("datajcuuyttuind")
- .withAdditionalProperties(mapOf()))
- .withDataset(
- new DatasetReference().withReferenceName("aubmcwpllo").withParameters(mapOf("tddigmmj", "datacdue")))
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datajrcrbkw")
- .withDisableMetricsCollection("datavg")
- .withAdditionalProperties(mapOf("type", "StoreReadSettings")));
+ DeleteActivity model
+ = new DeleteActivity().withName("bqkx")
+ .withDescription("ukajk")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("awynslcfx")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ri")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.COMPLETED, DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("qyjeeoytgny")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("txarl")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("tqc").withValue("datauozjgkcxb"),
+ new UserProperty().withName("nwiignr").withValue("dataqvrxouoqtestr")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("uaubmcwpll")
+ .withParameters(mapOf("ewtddigmmjve", "dataccd", "nvgxg", "datajrcrbkw", "jcemkcwcb", "dataih")))
+ .withPolicy(new ActivityPolicy().withTimeout("datajpiafzwhrgmznt")
+ .withRetry("dataafzrqmogfojrryz")
+ .withRetryIntervalInSeconds(543157036)
+ .withSecureInput(false)
+ .withSecureOutput(false)
+ .withAdditionalProperties(mapOf()))
+ .withRecursive("datararzk")
+ .withMaxConcurrentConnections(1386173284)
+ .withEnableLogging("datanvye")
+ .withLogStorageSettings(new LogStorageSettings()
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dvzomtzp")
+ .withParameters(mapOf("twzesejdcpcpeu", "dataxgslzbpnlfzqwmxu", "jrptltytbqhejhn",
+ "databofzmvtwyjc", "meeuuurx", "datajlbygq", "ob", "dataslxzwvygquiwcfq")))
+ .withPath("datawdevq")
+ .withLogLevel("dataejhvggykirqkskyy")
+ .withEnableReliableLogging("datammim")
+ .withAdditionalProperties(mapOf()))
+ .withDataset(
+ new DatasetReference().withReferenceName("sefezjyfaqdwfa")
+ .withParameters(mapOf("hwlvh", "datadetslxe", "zil", "datalxxgelad", "jjupukhxpixuyy",
+ "datarsycujnsznjsk")))
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datanfxsfjed")
+ .withDisableMetricsCollection("dataxicufxtcyteds")
+ .withAdditionalProperties(mapOf("type", "StoreReadSettings")));
model = BinaryData.fromObject(model).toObject(DeleteActivity.class);
- Assertions.assertEquals("qk", model.name());
- Assertions.assertEquals("zuk", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("qfqawynsl", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("arldsijcm", model.userProperties().get(0).name());
- Assertions.assertEquals("qjpi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(685032717, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals("bqkx", model.name());
+ Assertions.assertEquals("ukajk", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("awynslcfx", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("tqc", model.userProperties().get(0).name());
+ Assertions.assertEquals("uaubmcwpll", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(543157036, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(540501730, model.maxConcurrentConnections());
- Assertions.assertEquals("xxgeladqziljrsyc", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("aubmcwpllo", model.dataset().referenceName());
+ Assertions.assertEquals(1386173284, model.maxConcurrentConnections());
+ Assertions.assertEquals("dvzomtzp", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("sefezjyfaqdwfa", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTypePropertiesTests.java
index 9cb52b045c6c..c8ad6e89f6a6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DeleteActivityTypePropertiesTests.java
@@ -18,35 +18,34 @@ public final class DeleteActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DeleteActivityTypeProperties model = BinaryData.fromString(
- "{\"recursive\":\"dataraqesk\",\"maxConcurrentConnections\":1799759591,\"enableLogging\":\"datayyzaalpwwcwie\",\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"s\",\"parameters\":{\"mundlegdlcue\":\"dataqsndqjbdtczxw\"}},\"path\":\"datamqkwkutbtrhrygd\",\"logLevel\":\"dataufmvozq\",\"enableReliableLogging\":\"datacfppjegctsatnr\",\"\":{\"jprr\":\"datauewrwcqrvtwv\",\"cswadvbwewwd\":\"datahxqpmzznmn\"}},\"dataset\":{\"referenceName\":\"eiehwma\",\"parameters\":{\"dowsj\":\"datapagkmhbeneqapll\",\"halmhcatpwq\":\"datavpvtyullivcymnpb\",\"lpglhlwu\":\"dataqnajmwpeaoeggi\",\"oprnbozvi\":\"dataugru\"}},\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datahitqrpbwykeeocp\",\"disableMetricsCollection\":\"dataqzpkodbquvf\",\"\":{\"gwfqtqbn\":\"dataaozpcc\",\"wfdgeqzkpergzs\":\"datakmgydfmkz\"}}}")
+ "{\"recursive\":\"datauewrwcqrvtwv\",\"maxConcurrentConnections\":1816589211,\"enableLogging\":\"datarxhxqpm\",\"logStorageSettings\":{\"linkedServiceName\":{\"referenceName\":\"nmnscswadvbwewwd\",\"parameters\":{\"h\":\"dataehwmaxlppagk\",\"pllodowsjcvpvt\":\"dataeneq\"}},\"path\":\"datallivcymnpb\",\"logLevel\":\"dataalmhcatpwq\",\"enableReliableLogging\":\"datanajmwpeaoegg\",\"\":{\"lugrumoprnbo\":\"datapglhlw\",\"wykeeocpswqzpkod\":\"datavixamhitqrp\"}},\"dataset\":{\"referenceName\":\"quvf\",\"parameters\":{\"gwfqtqbn\":\"dataaozpcc\",\"wfdgeqzkpergzs\":\"datakmgydfmkz\"}},\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datakankjkszudx\",\"disableMetricsCollection\":\"dataf\",\"\":{\"jfmvydjax\":\"dataoqbruymapjnfofxi\",\"vugb\":\"datastuhlwzcn\"}}}")
.toObject(DeleteActivityTypeProperties.class);
- Assertions.assertEquals(1799759591, model.maxConcurrentConnections());
- Assertions.assertEquals("s", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("eiehwma", model.dataset().referenceName());
+ Assertions.assertEquals(1816589211, model.maxConcurrentConnections());
+ Assertions.assertEquals("nmnscswadvbwewwd", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("quvf", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DeleteActivityTypeProperties model = new DeleteActivityTypeProperties().withRecursive("dataraqesk")
- .withMaxConcurrentConnections(1799759591)
- .withEnableLogging("datayyzaalpwwcwie")
+ DeleteActivityTypeProperties model = new DeleteActivityTypeProperties().withRecursive("datauewrwcqrvtwv")
+ .withMaxConcurrentConnections(1816589211)
+ .withEnableLogging("datarxhxqpm")
.withLogStorageSettings(new LogStorageSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("s")
- .withParameters(mapOf("mundlegdlcue", "dataqsndqjbdtczxw")))
- .withPath("datamqkwkutbtrhrygd")
- .withLogLevel("dataufmvozq")
- .withEnableReliableLogging("datacfppjegctsatnr")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("nmnscswadvbwewwd")
+ .withParameters(mapOf("h", "dataehwmaxlppagk", "pllodowsjcvpvt", "dataeneq")))
+ .withPath("datallivcymnpb")
+ .withLogLevel("dataalmhcatpwq")
+ .withEnableReliableLogging("datanajmwpeaoegg")
.withAdditionalProperties(mapOf()))
- .withDataset(new DatasetReference().withReferenceName("eiehwma")
- .withParameters(mapOf("dowsj", "datapagkmhbeneqapll", "halmhcatpwq", "datavpvtyullivcymnpb", "lpglhlwu",
- "dataqnajmwpeaoeggi", "oprnbozvi", "dataugru")))
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datahitqrpbwykeeocp")
- .withDisableMetricsCollection("dataqzpkodbquvf")
+ .withDataset(new DatasetReference().withReferenceName("quvf")
+ .withParameters(mapOf("gwfqtqbn", "dataaozpcc", "wfdgeqzkpergzs", "datakmgydfmkz")))
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datakankjkszudx")
+ .withDisableMetricsCollection("dataf")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")));
model = BinaryData.fromObject(model).toObject(DeleteActivityTypeProperties.class);
- Assertions.assertEquals(1799759591, model.maxConcurrentConnections());
- Assertions.assertEquals("s", model.logStorageSettings().linkedServiceName().referenceName());
- Assertions.assertEquals("eiehwma", model.dataset().referenceName());
+ Assertions.assertEquals(1816589211, model.maxConcurrentConnections());
+ Assertions.assertEquals("nmnscswadvbwewwd", model.logStorageSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("quvf", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextReadSettingsTests.java
index 33c518babf9f..3432ee79278f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextReadSettingsTests.java
@@ -14,13 +14,13 @@ public final class DelimitedTextReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DelimitedTextReadSettings model = BinaryData.fromString(
- "{\"type\":\"DelimitedTextReadSettings\",\"skipLineCount\":\"datartr\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"fnaqclepcklowu\":\"datajeegzh\",\"lbljehw\":\"datahfwphnm\"}},\"\":{\"a\":\"datauofn\",\"kvnapxhtqwsdd\":\"dataah\",\"fkeubziibu\":\"dataaovubfl\",\"dwhvnjcbuzud\":\"databp\"}}")
+ "{\"type\":\"DelimitedTextReadSettings\",\"skipLineCount\":\"datawkesxvzcxxf\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"ycxmhorrecoiqw\":\"datagqwbrzkmgyl\",\"cyhjhrkfpt\":\"dataqliz\"}},\"\":{\"jdvfjvbwawymah\":\"datammisbfmbvmajcmpo\"}}")
.toObject(DelimitedTextReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DelimitedTextReadSettings model = new DelimitedTextReadSettings().withSkipLineCount("datartr")
+ DelimitedTextReadSettings model = new DelimitedTextReadSettings().withSkipLineCount("datawkesxvzcxxf")
.withCompressionProperties(
new CompressionReadSettings().withAdditionalProperties(mapOf("type", "CompressionReadSettings")));
model = BinaryData.fromObject(model).toObject(DelimitedTextReadSettings.class);
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSinkTests.java
index 667185fb1bb4..5926d8196ca9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSinkTests.java
@@ -17,30 +17,30 @@ public final class DelimitedTextSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DelimitedTextSink model = BinaryData.fromString(
- "{\"type\":\"DelimitedTextSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"dataewrb\",\"disableMetricsCollection\":\"dataj\",\"copyBehavior\":\"dataflqwqcxyiqppacji\",\"metadata\":[{\"name\":\"dataacy\",\"value\":\"datatkxeijzg\"},{\"name\":\"dataaaxttexaugojv\",\"value\":\"dataezrwboba\"},{\"name\":\"datantenhnqtvxghbehh\",\"value\":\"dataotqorrvwlce\"},{\"name\":\"datalyugzl\",\"value\":\"datajirj\"}],\"\":{\"gevjman\":\"datasyfdsgrtkevimru\",\"vtzdtwxfjlpkoc\":\"datarvvjoklb\",\"uvwlfzjrjgla\":\"dataexfmqfuflu\"}},\"formatSettings\":{\"type\":\"DelimitedTextWriteSettings\",\"quoteAllText\":\"datagzscgslwujk\",\"fileExtension\":\"dataytpmlrjn\",\"maxRowsPerFile\":\"datamodsytq\",\"fileNamePrefix\":\"dataatujphqvfxvv\",\"\":{\"pfnwdrmz\":\"dataghxoxwpiqkk\",\"khnrgmgnvc\":\"datamtsmeaciy\",\"bvlsnchy\":\"datasvidkzb\"}},\"writeBatchSize\":\"datafom\",\"writeBatchTimeout\":\"datakh\",\"sinkRetryCount\":\"datatecsmocqwey\",\"sinkRetryWait\":\"dataakettmfcxviwf\",\"maxConcurrentConnections\":\"datajxxbsafqiwldu\",\"disableMetricsCollection\":\"datasyjzdasgkfz\",\"\":{\"lbddlnzmff\":\"dataqomuzohnpkof\",\"junmgd\":\"datavowlammvazvwzien\",\"cuzvbreh\":\"dataxeivrhjxdnkgztf\",\"seiidfpwbybmxf\":\"datatqggzahngn\"}}")
+ "{\"type\":\"DelimitedTextSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datab\",\"disableMetricsCollection\":\"datad\",\"copyBehavior\":\"dataluvcwu\",\"metadata\":[{\"name\":\"dataxoaq\",\"value\":\"dataqfpkrmlbkvqog\"},{\"name\":\"datawfoqdn\",\"value\":\"datame\"},{\"name\":\"datanvscyu\",\"value\":\"datawsynt\"},{\"name\":\"datarluqaqn\",\"value\":\"datag\"}],\"\":{\"pifvpsmv\":\"datafejbozkl\"}},\"formatSettings\":{\"type\":\"DelimitedTextWriteSettings\",\"quoteAllText\":\"datauw\",\"fileExtension\":\"datasnplqfi\",\"maxRowsPerFile\":\"datafqmdjz\",\"fileNamePrefix\":\"datavmkplrjkmpaxoey\",\"\":{\"qhwfskmkdr\":\"datafaogvmqzagrq\",\"ldwcxjvexlutxcmc\":\"datakdpn\",\"yypvhdulds\":\"datacotqocn\",\"zzbr\":\"datal\"}},\"writeBatchSize\":\"datakeylk\",\"writeBatchTimeout\":\"dataaagrdfwvgl\",\"sinkRetryCount\":\"datasphvosucry\",\"sinkRetryWait\":\"dataohthzfotfrf\",\"maxConcurrentConnections\":\"datajkahdofshgmqx\",\"disableMetricsCollection\":\"datappnitrmzvnrfkzn\",\"\":{\"rxhwpgkrnx\":\"datattbmo\",\"gcnz\":\"datajmil\"}}")
.toObject(DelimitedTextSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DelimitedTextSink model = new DelimitedTextSink().withWriteBatchSize("datafom")
- .withWriteBatchTimeout("datakh")
- .withSinkRetryCount("datatecsmocqwey")
- .withSinkRetryWait("dataakettmfcxviwf")
- .withMaxConcurrentConnections("datajxxbsafqiwldu")
- .withDisableMetricsCollection("datasyjzdasgkfz")
- .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("dataewrb")
- .withDisableMetricsCollection("dataj")
- .withCopyBehavior("dataflqwqcxyiqppacji")
- .withMetadata(Arrays.asList(new MetadataItem().withName("dataacy").withValue("datatkxeijzg"),
- new MetadataItem().withName("dataaaxttexaugojv").withValue("dataezrwboba"),
- new MetadataItem().withName("datantenhnqtvxghbehh").withValue("dataotqorrvwlce"),
- new MetadataItem().withName("datalyugzl").withValue("datajirj")))
+ DelimitedTextSink model = new DelimitedTextSink().withWriteBatchSize("datakeylk")
+ .withWriteBatchTimeout("dataaagrdfwvgl")
+ .withSinkRetryCount("datasphvosucry")
+ .withSinkRetryWait("dataohthzfotfrf")
+ .withMaxConcurrentConnections("datajkahdofshgmqx")
+ .withDisableMetricsCollection("datappnitrmzvnrfkzn")
+ .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datab")
+ .withDisableMetricsCollection("datad")
+ .withCopyBehavior("dataluvcwu")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("dataxoaq").withValue("dataqfpkrmlbkvqog"),
+ new MetadataItem().withName("datawfoqdn").withValue("datame"),
+ new MetadataItem().withName("datanvscyu").withValue("datawsynt"),
+ new MetadataItem().withName("datarluqaqn").withValue("datag")))
.withAdditionalProperties(mapOf("type", "StoreWriteSettings")))
- .withFormatSettings(new DelimitedTextWriteSettings().withQuoteAllText("datagzscgslwujk")
- .withFileExtension("dataytpmlrjn")
- .withMaxRowsPerFile("datamodsytq")
- .withFileNamePrefix("dataatujphqvfxvv"));
+ .withFormatSettings(new DelimitedTextWriteSettings().withQuoteAllText("datauw")
+ .withFileExtension("datasnplqfi")
+ .withMaxRowsPerFile("datafqmdjz")
+ .withFileNamePrefix("datavmkplrjkmpaxoey"));
model = BinaryData.fromObject(model).toObject(DelimitedTextSink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSourceTests.java
index 42f567b9ea43..0f9ce989d568 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextSourceTests.java
@@ -16,24 +16,24 @@ public final class DelimitedTextSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DelimitedTextSource model = BinaryData.fromString(
- "{\"type\":\"DelimitedTextSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datav\",\"disableMetricsCollection\":\"datawdlduvimgtceor\",\"\":{\"afbjvbkjtgzk\":\"dataxta\"}},\"formatSettings\":{\"type\":\"DelimitedTextReadSettings\",\"skipLineCount\":\"dataavcipydnujgb\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"xpzsl\":\"datazprvpuacajxdrgxp\",\"qzkfgesdz\":\"datafrypzrycc\"}},\"\":{\"hioj\":\"datajhekbmdh\",\"ysbme\":\"datarhgpityeuv\",\"bznl\":\"dataf\",\"eywyftvy\":\"datahbkup\"}},\"additionalColumns\":\"datayqzjfvbnyyjvzlsc\",\"sourceRetryCount\":\"datavvsxm\",\"sourceRetryWait\":\"datassgbscq\",\"maxConcurrentConnections\":\"dataixazebmmjaigaxwq\",\"disableMetricsCollection\":\"dataarct\",\"\":{\"whoosrsolhhv\":\"dataggtdvhokxxf\",\"giqhj\":\"datafoej\",\"udifierxxorsdvu\":\"datael\"}}")
+ "{\"type\":\"DelimitedTextSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datapsnnnxhgdnsdxyln\",\"disableMetricsCollection\":\"datagaicjkqjz\",\"\":{\"kqlkaipfyvquas\":\"datahdnpnmrxjd\",\"vakqaho\":\"dataywkbiek\",\"voaoavezwclmzm\":\"datagnapkpaiedo\",\"rcdiqhvhcbukaw\":\"datarvlgh\"}},\"formatSettings\":{\"type\":\"DelimitedTextReadSettings\",\"skipLineCount\":\"datafjtockgqaawyysz\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"zsipkhqhvktc\":\"dataljlwfqrfyw\"}},\"\":{\"xemvl\":\"dataqdkhohspk\",\"rjzbxxxqfrntzbh\":\"dataa\"}},\"additionalColumns\":\"datalpxfauvgtoin\",\"sourceRetryCount\":\"datasmyvvfapfbm\",\"sourceRetryWait\":\"datahknefcoo\",\"maxConcurrentConnections\":\"datamdspd\",\"disableMetricsCollection\":\"datagupiosibg\",\"\":{\"kyrttnriks\":\"dataxuybxjwnyr\"}}")
.toObject(DelimitedTextSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DelimitedTextSource model
- = new DelimitedTextSource().withSourceRetryCount("datavvsxm")
- .withSourceRetryWait("datassgbscq")
- .withMaxConcurrentConnections("dataixazebmmjaigaxwq")
- .withDisableMetricsCollection("dataarct")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datav")
- .withDisableMetricsCollection("datawdlduvimgtceor")
+ = new DelimitedTextSource().withSourceRetryCount("datasmyvvfapfbm")
+ .withSourceRetryWait("datahknefcoo")
+ .withMaxConcurrentConnections("datamdspd")
+ .withDisableMetricsCollection("datagupiosibg")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datapsnnnxhgdnsdxyln")
+ .withDisableMetricsCollection("datagaicjkqjz")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
- .withFormatSettings(new DelimitedTextReadSettings().withSkipLineCount("dataavcipydnujgb")
+ .withFormatSettings(new DelimitedTextReadSettings().withSkipLineCount("datafjtockgqaawyysz")
.withCompressionProperties(new CompressionReadSettings()
.withAdditionalProperties(mapOf("type", "CompressionReadSettings"))))
- .withAdditionalColumns("datayqzjfvbnyyjvzlsc");
+ .withAdditionalColumns("datalpxfauvgtoin");
model = BinaryData.fromObject(model).toObject(DelimitedTextSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextWriteSettingsTests.java
index 86281fc35ac7..3f1039ebb34f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DelimitedTextWriteSettingsTests.java
@@ -11,16 +11,16 @@ public final class DelimitedTextWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DelimitedTextWriteSettings model = BinaryData.fromString(
- "{\"type\":\"DelimitedTextWriteSettings\",\"quoteAllText\":\"dataorrecoiqwnqliz\",\"fileExtension\":\"datacyhjhrkfpt\",\"maxRowsPerFile\":\"dataomm\",\"fileNamePrefix\":\"databfm\",\"\":{\"wawymahboind\":\"dataajcmpohjdvfjv\",\"ugcjssqpkm\":\"datauyqdj\",\"qjyiwuveryavb\":\"dataryhvshkvupbzqwwt\",\"fas\":\"datavvcogupsho\"}}")
+ "{\"type\":\"DelimitedTextWriteSettings\",\"quoteAllText\":\"datawyzxqhuhmldhnz\",\"fileExtension\":\"datackfu\",\"maxRowsPerFile\":\"datachotdzt\",\"fileNamePrefix\":\"dataqhwpuaermaww\",\"\":{\"qcemco\":\"datada\",\"hisxz\":\"datawfuo\",\"oj\":\"dataikvdfszxbupsx\",\"zlmwfncwlwov\":\"datagxcgqkhyvtajwkrx\"}}")
.toObject(DelimitedTextWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DelimitedTextWriteSettings model = new DelimitedTextWriteSettings().withQuoteAllText("dataorrecoiqwnqliz")
- .withFileExtension("datacyhjhrkfpt")
- .withMaxRowsPerFile("dataomm")
- .withFileNamePrefix("databfm");
+ DelimitedTextWriteSettings model = new DelimitedTextWriteSettings().withQuoteAllText("datawyzxqhuhmldhnz")
+ .withFileExtension("datackfu")
+ .withMaxRowsPerFile("datachotdzt")
+ .withFileNamePrefix("dataqhwpuaermaww");
model = BinaryData.fromObject(model).toObject(DelimitedTextWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DistcpSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DistcpSettingsTests.java
index 955f19e4d1e2..7c686832d295 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DistcpSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DistcpSettingsTests.java
@@ -11,15 +11,15 @@ public final class DistcpSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DistcpSettings model = BinaryData.fromString(
- "{\"resourceManagerEndpoint\":\"dataqkmihggvyhqwyxba\",\"tempScriptPath\":\"datarviynlslgxifkds\",\"distcpOptions\":\"dataqwkddgep\"}")
+ "{\"resourceManagerEndpoint\":\"datatrooaahhvs\",\"tempScriptPath\":\"datagywkin\",\"distcpOptions\":\"datavtx\"}")
.toObject(DistcpSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DistcpSettings model = new DistcpSettings().withResourceManagerEndpoint("dataqkmihggvyhqwyxba")
- .withTempScriptPath("datarviynlslgxifkds")
- .withDistcpOptions("dataqwkddgep");
+ DistcpSettings model = new DistcpSettings().withResourceManagerEndpoint("datatrooaahhvs")
+ .withTempScriptPath("datagywkin")
+ .withDistcpOptions("datavtx");
model = BinaryData.fromObject(model).toObject(DistcpSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTests.java
index 014c6c364aa3..cfb6784eaf32 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTests.java
@@ -19,32 +19,31 @@ public final class DocumentDbCollectionDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DocumentDbCollectionDataset model = BinaryData.fromString(
- "{\"type\":\"DocumentDbCollection\",\"typeProperties\":{\"collectionName\":\"dataflcezs\"},\"description\":\"vwiftd\",\"structure\":\"datavbfpfhru\",\"schema\":\"datasyqcjnqswxdowum\",\"linkedServiceName\":{\"referenceName\":\"qukr\",\"parameters\":{\"eddp\":\"dataohclqddnhfkneb\",\"smkaqldqab\":\"datayzcwy\",\"bbigcfd\":\"datawvpaqbqx\",\"bmjyyrqaedwovoc\":\"dataofxn\"}},\"parameters\":{\"adhed\":{\"type\":\"Float\",\"defaultValue\":\"dataeayokrwfmihw\"}},\"annotations\":[\"databdczvothmkhjao\"],\"folder\":{\"name\":\"wfcn\"},\"\":{\"lhscmyh\":\"datapo\",\"okndwpppqwojoevz\":\"datahjvszfq\",\"zlyvapbkrbuog\":\"dataufytdxmly\",\"cuhaizijv\":\"datatdlt\"}}")
+ "{\"type\":\"DocumentDbCollection\",\"typeProperties\":{\"collectionName\":\"dataghmmtbtdvucfvvra\"},\"description\":\"eurdeewlsuxp\",\"structure\":\"datawkdwjyjiznioroof\",\"schema\":\"datataspmcrei\",\"linkedServiceName\":{\"referenceName\":\"uftrni\",\"parameters\":{\"wfmsxj\":\"datainuwqxungrob\"}},\"parameters\":{\"ugeerclbltbhpwac\":{\"type\":\"Array\",\"defaultValue\":\"dataxmvzjow\"}},\"annotations\":[\"dataurjwmvwryvdifkii\",\"datagpruccwme\",\"databtxsytrtexeg\"],\"folder\":{\"name\":\"qjywi\"},\"\":{\"ndiloqkajwjuria\":\"dataycfjnc\",\"llanhzc\":\"datasb\",\"ygzkztxfexwacyy\":\"datanjxizbax\"}}")
.toObject(DocumentDbCollectionDataset.class);
- Assertions.assertEquals("vwiftd", model.description());
- Assertions.assertEquals("qukr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("adhed").type());
- Assertions.assertEquals("wfcn", model.folder().name());
+ Assertions.assertEquals("eurdeewlsuxp", model.description());
+ Assertions.assertEquals("uftrni", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ugeerclbltbhpwac").type());
+ Assertions.assertEquals("qjywi", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DocumentDbCollectionDataset model = new DocumentDbCollectionDataset().withDescription("vwiftd")
- .withStructure("datavbfpfhru")
- .withSchema("datasyqcjnqswxdowum")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qukr")
- .withParameters(mapOf("eddp", "dataohclqddnhfkneb", "smkaqldqab", "datayzcwy", "bbigcfd",
- "datawvpaqbqx", "bmjyyrqaedwovoc", "dataofxn")))
- .withParameters(mapOf("adhed",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataeayokrwfmihw")))
- .withAnnotations(Arrays.asList("databdczvothmkhjao"))
- .withFolder(new DatasetFolder().withName("wfcn"))
- .withCollectionName("dataflcezs");
+ DocumentDbCollectionDataset model = new DocumentDbCollectionDataset().withDescription("eurdeewlsuxp")
+ .withStructure("datawkdwjyjiznioroof")
+ .withSchema("datataspmcrei")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("uftrni")
+ .withParameters(mapOf("wfmsxj", "datainuwqxungrob")))
+ .withParameters(mapOf("ugeerclbltbhpwac",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataxmvzjow")))
+ .withAnnotations(Arrays.asList("dataurjwmvwryvdifkii", "datagpruccwme", "databtxsytrtexeg"))
+ .withFolder(new DatasetFolder().withName("qjywi"))
+ .withCollectionName("dataghmmtbtdvucfvvra");
model = BinaryData.fromObject(model).toObject(DocumentDbCollectionDataset.class);
- Assertions.assertEquals("vwiftd", model.description());
- Assertions.assertEquals("qukr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("adhed").type());
- Assertions.assertEquals("wfcn", model.folder().name());
+ Assertions.assertEquals("eurdeewlsuxp", model.description());
+ Assertions.assertEquals("uftrni", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ugeerclbltbhpwac").type());
+ Assertions.assertEquals("qjywi", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTypePropertiesTests.java
index e2e243b9e3d1..5bed7c95f09d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class DocumentDbCollectionDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DocumentDbCollectionDatasetTypeProperties model
- = BinaryData.fromString("{\"collectionName\":\"dataylzeohlpsftq\"}")
+ = BinaryData.fromString("{\"collectionName\":\"datamlxppdndzkfevuii\"}")
.toObject(DocumentDbCollectionDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DocumentDbCollectionDatasetTypeProperties model
- = new DocumentDbCollectionDatasetTypeProperties().withCollectionName("dataylzeohlpsftq");
+ = new DocumentDbCollectionDatasetTypeProperties().withCollectionName("datamlxppdndzkfevuii");
model = BinaryData.fromObject(model).toObject(DocumentDbCollectionDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSinkTests.java
index cbcf31ac8785..9d56b83f8af9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSinkTests.java
@@ -11,20 +11,20 @@ public final class DocumentDbCollectionSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DocumentDbCollectionSink model = BinaryData.fromString(
- "{\"type\":\"DocumentDbCollectionSink\",\"nestingSeparator\":\"dataoqegerxmlfn\",\"writeBehavior\":\"datalmyrkrtd\",\"writeBatchSize\":\"dataoxzwgrs\",\"writeBatchTimeout\":\"datatlmcaehjhwklf\",\"sinkRetryCount\":\"dataqqgyp\",\"sinkRetryWait\":\"datawejbngojnak\",\"maxConcurrentConnections\":\"dataytk\",\"disableMetricsCollection\":\"datafo\",\"\":{\"wxmnrdfjobhrvon\":\"dataksormfhru\",\"pbdfrtasau\":\"dataaupjmjig\"}}")
+ "{\"type\":\"DocumentDbCollectionSink\",\"nestingSeparator\":\"datazvveer\",\"writeBehavior\":\"dataehsnlmdosiyzfdc\",\"writeBatchSize\":\"datakggbmzdnyrmolm\",\"writeBatchTimeout\":\"datakcpumckcbsa\",\"sinkRetryCount\":\"dataucsscwdqilz\",\"sinkRetryWait\":\"datai\",\"maxConcurrentConnections\":\"datarqzwypwh\",\"disableMetricsCollection\":\"databflrpvcgqqxek\",\"\":{\"vfjkxxnqrqdx\":\"datapsqvuisedeq\",\"lsvicvpagwohkro\":\"databtpvwx\",\"mlozjyovrllvhbgk\":\"datazss\"}}")
.toObject(DocumentDbCollectionSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DocumentDbCollectionSink model = new DocumentDbCollectionSink().withWriteBatchSize("dataoxzwgrs")
- .withWriteBatchTimeout("datatlmcaehjhwklf")
- .withSinkRetryCount("dataqqgyp")
- .withSinkRetryWait("datawejbngojnak")
- .withMaxConcurrentConnections("dataytk")
- .withDisableMetricsCollection("datafo")
- .withNestingSeparator("dataoqegerxmlfn")
- .withWriteBehavior("datalmyrkrtd");
+ DocumentDbCollectionSink model = new DocumentDbCollectionSink().withWriteBatchSize("datakggbmzdnyrmolm")
+ .withWriteBatchTimeout("datakcpumckcbsa")
+ .withSinkRetryCount("dataucsscwdqilz")
+ .withSinkRetryWait("datai")
+ .withMaxConcurrentConnections("datarqzwypwh")
+ .withDisableMetricsCollection("databflrpvcgqqxek")
+ .withNestingSeparator("datazvveer")
+ .withWriteBehavior("dataehsnlmdosiyzfdc");
model = BinaryData.fromObject(model).toObject(DocumentDbCollectionSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSourceTests.java
index 9069a34f2888..ac91cd84efe9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DocumentDbCollectionSourceTests.java
@@ -11,20 +11,20 @@ public final class DocumentDbCollectionSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DocumentDbCollectionSource model = BinaryData.fromString(
- "{\"type\":\"DocumentDbCollectionSource\",\"query\":\"datal\",\"nestingSeparator\":\"dataeqotvocjktihnwyv\",\"queryTimeout\":\"datasgfdmtfnbvtxq\",\"additionalColumns\":\"datab\",\"sourceRetryCount\":\"dataqbdiahjxcdhp\",\"sourceRetryWait\":\"dataxwsfddy\",\"maxConcurrentConnections\":\"datafyntow\",\"disableMetricsCollection\":\"datasur\",\"\":{\"izqvga\":\"datajzsjhhru\",\"epnglzjhaqx\":\"datao\"}}")
+ "{\"type\":\"DocumentDbCollectionSource\",\"query\":\"datadljqjstncjwz\",\"nestingSeparator\":\"datatezltlundkj\",\"queryTimeout\":\"datavhhxivshjuxm\",\"additionalColumns\":\"dataythxearlp\",\"sourceRetryCount\":\"datajjticly\",\"sourceRetryWait\":\"dataduxbungmpn\",\"maxConcurrentConnections\":\"datatgucdfxglrcj\",\"disableMetricsCollection\":\"dataoaz\",\"\":{\"nyhzestt\":\"datajcwuzanpoyrqjoni\"}}")
.toObject(DocumentDbCollectionSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DocumentDbCollectionSource model = new DocumentDbCollectionSource().withSourceRetryCount("dataqbdiahjxcdhp")
- .withSourceRetryWait("dataxwsfddy")
- .withMaxConcurrentConnections("datafyntow")
- .withDisableMetricsCollection("datasur")
- .withQuery("datal")
- .withNestingSeparator("dataeqotvocjktihnwyv")
- .withQueryTimeout("datasgfdmtfnbvtxq")
- .withAdditionalColumns("datab");
+ DocumentDbCollectionSource model = new DocumentDbCollectionSource().withSourceRetryCount("datajjticly")
+ .withSourceRetryWait("dataduxbungmpn")
+ .withMaxConcurrentConnections("datatgucdfxglrcj")
+ .withDisableMetricsCollection("dataoaz")
+ .withQuery("datadljqjstncjwz")
+ .withNestingSeparator("datatezltlundkj")
+ .withQueryTimeout("datavhhxivshjuxm")
+ .withAdditionalColumns("dataythxearlp");
model = BinaryData.fromObject(model).toObject(DocumentDbCollectionSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillDatasetTypePropertiesTests.java
index 82e639437309..da98cb9dfc12 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillDatasetTypePropertiesTests.java
@@ -11,15 +11,15 @@ public final class DrillDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DrillDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"datavpnyldjd\",\"table\":\"datavdryknkx\",\"schema\":\"dataxhnrjl\"}")
+ .fromString("{\"tableName\":\"datanyfowyj\",\"table\":\"dataakkiub\",\"schema\":\"datakittlrgl\"}")
.toObject(DrillDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DrillDatasetTypeProperties model = new DrillDatasetTypeProperties().withTableName("datavpnyldjd")
- .withTable("datavdryknkx")
- .withSchema("dataxhnrjl");
+ DrillDatasetTypeProperties model = new DrillDatasetTypeProperties().withTableName("datanyfowyj")
+ .withTable("dataakkiub")
+ .withSchema("datakittlrgl");
model = BinaryData.fromObject(model).toObject(DrillDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillSourceTests.java
index 18f9d8c49fed..88fe2c5482fe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillSourceTests.java
@@ -11,19 +11,19 @@ public final class DrillSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DrillSource model = BinaryData.fromString(
- "{\"type\":\"DrillSource\",\"query\":\"dataaysxhfupvqjkqlaf\",\"queryTimeout\":\"dataywmcipuye\",\"additionalColumns\":\"datahd\",\"sourceRetryCount\":\"datagaifg\",\"sourceRetryWait\":\"datakgqwmp\",\"maxConcurrentConnections\":\"dataxpcxqcbnkxhcodh\",\"disableMetricsCollection\":\"databxllfwxdou\",\"\":{\"ofhk\":\"datapaqjahjxgedtmz\",\"rfassiii\":\"dataywtacgukierd\",\"ayyxgcgb\":\"datacmrgahs\",\"vqopxun\":\"dataieqonsbukznxd\"}}")
+ "{\"type\":\"DrillSource\",\"query\":\"datafn\",\"queryTimeout\":\"dataeyavldovpwrq\",\"additionalColumns\":\"datazokplzliizb\",\"sourceRetryCount\":\"datajumulhfq\",\"sourceRetryWait\":\"datanchah\",\"maxConcurrentConnections\":\"datanrptrqcap\",\"disableMetricsCollection\":\"datafvowzbk\",\"\":{\"qzzkplqmca\":\"datapzdpujywjmo\",\"jgfpqwwugfwpvj\":\"dataseiauveeng\"}}")
.toObject(DrillSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DrillSource model = new DrillSource().withSourceRetryCount("datagaifg")
- .withSourceRetryWait("datakgqwmp")
- .withMaxConcurrentConnections("dataxpcxqcbnkxhcodh")
- .withDisableMetricsCollection("databxllfwxdou")
- .withQueryTimeout("dataywmcipuye")
- .withAdditionalColumns("datahd")
- .withQuery("dataaysxhfupvqjkqlaf");
+ DrillSource model = new DrillSource().withSourceRetryCount("datajumulhfq")
+ .withSourceRetryWait("datanchah")
+ .withMaxConcurrentConnections("datanrptrqcap")
+ .withDisableMetricsCollection("datafvowzbk")
+ .withQueryTimeout("dataeyavldovpwrq")
+ .withAdditionalColumns("datazokplzliizb")
+ .withQuery("datafn");
model = BinaryData.fromObject(model).toObject(DrillSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillTableDatasetTests.java
index 5f977b64a800..8ca81f05e310 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DrillTableDatasetTests.java
@@ -19,43 +19,39 @@ public final class DrillTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DrillTableDataset model = BinaryData.fromString(
- "{\"type\":\"DrillTable\",\"typeProperties\":{\"tableName\":\"dataugdcr\",\"table\":\"databplvhmhur\",\"schema\":\"datadjlz\"},\"description\":\"m\",\"structure\":\"dataghqeuyaorservpv\",\"schema\":\"dataorsbeg\",\"linkedServiceName\":{\"referenceName\":\"lmexafjqzyhz\",\"parameters\":{\"nsskydigt\":\"datavtuqvirl\",\"ocsvjekejchxzj\":\"datajx\",\"yfyixecmasjnfgng\":\"datacwuzs\"}},\"parameters\":{\"wxtxuzhvojyf\":{\"type\":\"String\",\"defaultValue\":\"dataeyvfxbfckmoaljax\"},\"jef\":{\"type\":\"Float\",\"defaultValue\":\"datalbkjcdzuiygtcyz\"},\"lrlkbh\":{\"type\":\"Int\",\"defaultValue\":\"dataaldjcgldry\"},\"xefppq\":{\"type\":\"String\",\"defaultValue\":\"datamxcaujbfomfbozpj\"}},\"annotations\":[\"datannjjthpsnxebycy\",\"datapohxubn\"],\"folder\":{\"name\":\"sebcxno\"},\"\":{\"gspjlf\":\"datadyzssjlmykdygj\",\"ngwqxcrbcrgyoim\":\"datah\",\"z\":\"datas\",\"htvagwnnw\":\"datacctvkog\"}}")
+ "{\"type\":\"DrillTable\",\"typeProperties\":{\"tableName\":\"datafvkywzrqeiad\",\"table\":\"datakhuvnl\",\"schema\":\"datacnuti\"},\"description\":\"mizunzbqvioync\",\"structure\":\"dataqhhvvwz\",\"schema\":\"datajaaaiaibtvavly\",\"linkedServiceName\":{\"referenceName\":\"qtlocnwmef\",\"parameters\":{\"bzgy\":\"datauzqcrlkor\",\"nozf\":\"dataenfsfyqncowm\",\"agwaakktbjort\":\"dataywjiaaosla\"}},\"parameters\":{\"zbkd\":{\"type\":\"Bool\",\"defaultValue\":\"dataqhsnsejplislxyl\"},\"rpea\":{\"type\":\"Object\",\"defaultValue\":\"datajwxgvtkjct\"},\"aitrms\":{\"type\":\"Float\",\"defaultValue\":\"datakvfccozvqxspht\"},\"poegyckm\":{\"type\":\"SecureString\",\"defaultValue\":\"datatuytgcptct\"}},\"annotations\":[\"datavrcclclfkfv\",\"dataj\"],\"folder\":{\"name\":\"wrvp\"},\"\":{\"b\":\"datajylxt\",\"aysqwh\":\"datasewfzvv\",\"tcvpvdfmo\":\"datadcyandblkb\",\"sqpffapjpjmsbzz\":\"dataqctfvxu\"}}")
.toObject(DrillTableDataset.class);
- Assertions.assertEquals("m", model.description());
- Assertions.assertEquals("lmexafjqzyhz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("wxtxuzhvojyf").type());
- Assertions.assertEquals("sebcxno", model.folder().name());
+ Assertions.assertEquals("mizunzbqvioync", model.description());
+ Assertions.assertEquals("qtlocnwmef", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("zbkd").type());
+ Assertions.assertEquals("wrvp", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DrillTableDataset model
- = new DrillTableDataset().withDescription("m")
- .withStructure("dataghqeuyaorservpv")
- .withSchema("dataorsbeg")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lmexafjqzyhz")
- .withParameters(mapOf("nsskydigt", "datavtuqvirl", "ocsvjekejchxzj", "datajx", "yfyixecmasjnfgng",
- "datacwuzs")))
- .withParameters(mapOf("wxtxuzhvojyf",
- new ParameterSpecification().withType(ParameterType.STRING)
- .withDefaultValue("dataeyvfxbfckmoaljax"),
- "jef",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datalbkjcdzuiygtcyz"),
- "lrlkbh",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataaldjcgldry"),
- "xefppq",
- new ParameterSpecification().withType(ParameterType.STRING)
- .withDefaultValue("datamxcaujbfomfbozpj")))
- .withAnnotations(Arrays.asList("datannjjthpsnxebycy", "datapohxubn"))
- .withFolder(new DatasetFolder().withName("sebcxno"))
- .withTableName("dataugdcr")
- .withTable("databplvhmhur")
- .withSchemaTypePropertiesSchema("datadjlz");
+ DrillTableDataset model = new DrillTableDataset().withDescription("mizunzbqvioync")
+ .withStructure("dataqhhvvwz")
+ .withSchema("datajaaaiaibtvavly")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qtlocnwmef")
+ .withParameters(
+ mapOf("bzgy", "datauzqcrlkor", "nozf", "dataenfsfyqncowm", "agwaakktbjort", "dataywjiaaosla")))
+ .withParameters(mapOf("zbkd",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataqhsnsejplislxyl"),
+ "rpea", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datajwxgvtkjct"),
+ "aitrms",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datakvfccozvqxspht"),
+ "poegyckm",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datatuytgcptct")))
+ .withAnnotations(Arrays.asList("datavrcclclfkfv", "dataj"))
+ .withFolder(new DatasetFolder().withName("wrvp"))
+ .withTableName("datafvkywzrqeiad")
+ .withTable("datakhuvnl")
+ .withSchemaTypePropertiesSchema("datacnuti");
model = BinaryData.fromObject(model).toObject(DrillTableDataset.class);
- Assertions.assertEquals("m", model.description());
- Assertions.assertEquals("lmexafjqzyhz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("wxtxuzhvojyf").type());
- Assertions.assertEquals("sebcxno", model.folder().name());
+ Assertions.assertEquals("mizunzbqvioync", model.description());
+ Assertions.assertEquals("qtlocnwmef", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("zbkd").type());
+ Assertions.assertEquals("wrvp", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTests.java
index c7240194a476..66bf7a0fc7a9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTests.java
@@ -19,34 +19,32 @@ public final class DynamicsAXResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DynamicsAXResourceDataset model = BinaryData.fromString(
- "{\"type\":\"DynamicsAXResource\",\"typeProperties\":{\"path\":\"datahrau\"},\"description\":\"ovlx\",\"structure\":\"datavm\",\"schema\":\"datapniqwxmrgmnkgtlh\",\"linkedServiceName\":{\"referenceName\":\"krazkioiyecz\",\"parameters\":{\"qzhehgvmmnoyzg\":\"datamsvzngh\",\"pluzypkf\":\"databn\",\"xilzvxot\":\"datadf\",\"ytsqmbwcacwaaqa\":\"dataoilqcdvhyefqh\"}},\"parameters\":{\"qlreqbrcmmdts\":{\"type\":\"Int\",\"defaultValue\":\"dataaxxra\"},\"cznbabow\":{\"type\":\"Bool\",\"defaultValue\":\"datamx\"},\"ejh\":{\"type\":\"Int\",\"defaultValue\":\"datarnmjwkowxqzkkag\"}},\"annotations\":[\"dataphr\"],\"folder\":{\"name\":\"peajzzy\"},\"\":{\"eyrftxytjayp\":\"dataamzmzfnt\"}}")
+ "{\"type\":\"DynamicsAXResource\",\"typeProperties\":{\"path\":\"datamv\"},\"description\":\"flhdhoxu\",\"structure\":\"datacnnkvthwtam\",\"schema\":\"databgy\",\"linkedServiceName\":{\"referenceName\":\"xh\",\"parameters\":{\"beqzjdwxtutpdwne\":\"datahkezuucqicocdx\"}},\"parameters\":{\"rwvn\":{\"type\":\"Bool\",\"defaultValue\":\"datalxug\"}},\"annotations\":[\"dataofkvfruxz\",\"datafbvhgykzov\",\"datatvymdqaymqmyrn\",\"datagubqkfnoxhvoyj\"],\"folder\":{\"name\":\"krqs\"},\"\":{\"eexweju\":\"datapakxr\",\"zoytkbeadyfenro\":\"datauvnxbohpzur\",\"cbtaxdrpanhsxwhx\":\"dataoijoxcbpkiwse\"}}")
.toObject(DynamicsAXResourceDataset.class);
- Assertions.assertEquals("ovlx", model.description());
- Assertions.assertEquals("krazkioiyecz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("qlreqbrcmmdts").type());
- Assertions.assertEquals("peajzzy", model.folder().name());
+ Assertions.assertEquals("flhdhoxu", model.description());
+ Assertions.assertEquals("xh", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("rwvn").type());
+ Assertions.assertEquals("krqs", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DynamicsAXResourceDataset model = new DynamicsAXResourceDataset().withDescription("ovlx")
- .withStructure("datavm")
- .withSchema("datapniqwxmrgmnkgtlh")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("krazkioiyecz")
- .withParameters(mapOf("qzhehgvmmnoyzg", "datamsvzngh", "pluzypkf", "databn", "xilzvxot", "datadf",
- "ytsqmbwcacwaaqa", "dataoilqcdvhyefqh")))
- .withParameters(mapOf("qlreqbrcmmdts",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataaxxra"), "cznbabow",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datamx"), "ejh",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datarnmjwkowxqzkkag")))
- .withAnnotations(Arrays.asList("dataphr"))
- .withFolder(new DatasetFolder().withName("peajzzy"))
- .withPath("datahrau");
+ DynamicsAXResourceDataset model = new DynamicsAXResourceDataset().withDescription("flhdhoxu")
+ .withStructure("datacnnkvthwtam")
+ .withSchema("databgy")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xh")
+ .withParameters(mapOf("beqzjdwxtutpdwne", "datahkezuucqicocdx")))
+ .withParameters(
+ mapOf("rwvn", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datalxug")))
+ .withAnnotations(
+ Arrays.asList("dataofkvfruxz", "datafbvhgykzov", "datatvymdqaymqmyrn", "datagubqkfnoxhvoyj"))
+ .withFolder(new DatasetFolder().withName("krqs"))
+ .withPath("datamv");
model = BinaryData.fromObject(model).toObject(DynamicsAXResourceDataset.class);
- Assertions.assertEquals("ovlx", model.description());
- Assertions.assertEquals("krazkioiyecz", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("qlreqbrcmmdts").type());
- Assertions.assertEquals("peajzzy", model.folder().name());
+ Assertions.assertEquals("flhdhoxu", model.description());
+ Assertions.assertEquals("xh", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("rwvn").type());
+ Assertions.assertEquals("krqs", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTypePropertiesTests.java
index 515b1bf9e2a2..d1649de74873 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXResourceDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class DynamicsAXResourceDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- DynamicsAXResourceDatasetTypeProperties model
- = BinaryData.fromString("{\"path\":\"datadrj\"}").toObject(DynamicsAXResourceDatasetTypeProperties.class);
+ DynamicsAXResourceDatasetTypeProperties model = BinaryData.fromString("{\"path\":\"dataztdacrqcwkk\"}")
+ .toObject(DynamicsAXResourceDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DynamicsAXResourceDatasetTypeProperties model
- = new DynamicsAXResourceDatasetTypeProperties().withPath("datadrj");
+ = new DynamicsAXResourceDatasetTypeProperties().withPath("dataztdacrqcwkk");
model = BinaryData.fromObject(model).toObject(DynamicsAXResourceDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXSourceTests.java
index e2abcadb2677..97186b4f308a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsAXSourceTests.java
@@ -11,20 +11,20 @@ public final class DynamicsAXSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DynamicsAXSource model = BinaryData.fromString(
- "{\"type\":\"DynamicsAXSource\",\"query\":\"datat\",\"httpRequestTimeout\":\"datauvwzjycgc\",\"queryTimeout\":\"dataagxikzvnghtknrw\",\"additionalColumns\":\"dataysnmy\",\"sourceRetryCount\":\"datafmlcnrapxw\",\"sourceRetryWait\":\"datapxoelfobehr\",\"maxConcurrentConnections\":\"dataglojjcziytf\",\"disableMetricsCollection\":\"datavirmbr\",\"\":{\"hkdzvuhw\":\"datanqahnkmsfy\"}}")
+ "{\"type\":\"DynamicsAXSource\",\"query\":\"datalyi\",\"httpRequestTimeout\":\"datazgmxqa\",\"queryTimeout\":\"dataypxgoypo\",\"additionalColumns\":\"dataoyyfysn\",\"sourceRetryCount\":\"datajnl\",\"sourceRetryWait\":\"datacmhonojese\",\"maxConcurrentConnections\":\"dataxel\",\"disableMetricsCollection\":\"dataxwmpziy\",\"\":{\"wpcutzlvx\":\"datajswedkfofyfwpu\",\"vddwgozr\":\"dataolvedzrjkrpor\",\"dyhcwcgvyuuse\":\"dataglkmgcxmkrldfo\"}}")
.toObject(DynamicsAXSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DynamicsAXSource model = new DynamicsAXSource().withSourceRetryCount("datafmlcnrapxw")
- .withSourceRetryWait("datapxoelfobehr")
- .withMaxConcurrentConnections("dataglojjcziytf")
- .withDisableMetricsCollection("datavirmbr")
- .withQueryTimeout("dataagxikzvnghtknrw")
- .withAdditionalColumns("dataysnmy")
- .withQuery("datat")
- .withHttpRequestTimeout("datauvwzjycgc");
+ DynamicsAXSource model = new DynamicsAXSource().withSourceRetryCount("datajnl")
+ .withSourceRetryWait("datacmhonojese")
+ .withMaxConcurrentConnections("dataxel")
+ .withDisableMetricsCollection("dataxwmpziy")
+ .withQueryTimeout("dataypxgoypo")
+ .withAdditionalColumns("dataoyyfysn")
+ .withQuery("datalyi")
+ .withHttpRequestTimeout("datazgmxqa");
model = BinaryData.fromObject(model).toObject(DynamicsAXSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTests.java
index adf8487cb65c..cd45b03ba7ce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTests.java
@@ -19,32 +19,38 @@ public final class DynamicsCrmEntityDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DynamicsCrmEntityDataset model = BinaryData.fromString(
- "{\"type\":\"DynamicsCrmEntity\",\"typeProperties\":{\"entityName\":\"datafkiikgpruccwm\"},\"description\":\"btxsytrtexeg\",\"structure\":\"datarqjywiwhvycfjn\",\"schema\":\"datandiloqkajwjuria\",\"linkedServiceName\":{\"referenceName\":\"sb\",\"parameters\":{\"knjxizbaxdy\":\"dataanhz\",\"xfexwacy\":\"datazkz\",\"kfevui\":\"datajmlxppdnd\",\"ibfkcjytq\":\"datau\"}},\"parameters\":{\"m\":{\"type\":\"Float\",\"defaultValue\":\"dataqqfopvno\"}},\"annotations\":[\"datasfhoxqlyo\"],\"folder\":{\"name\":\"fbkmvldzmxojzsv\"},\"\":{\"ergwlckihbam\":\"datagbqkvhyejthgeecb\",\"jwdizcrjixiujz\":\"dataqsokknpug\",\"exgkrsw\":\"datac\"}}")
+ "{\"type\":\"DynamicsCrmEntity\",\"typeProperties\":{\"entityName\":\"dataeepfh\"},\"description\":\"nn\",\"structure\":\"dataxqhpjhuboh\",\"schema\":\"datazgaybvr\",\"linkedServiceName\":{\"referenceName\":\"hogalg\",\"parameters\":{\"pamqxfcssanybz\":\"datafmzvztaue\",\"svcdhlywkh\":\"dataghvdfeumy\",\"nzxezriwgo\":\"dataokj\"}},\"parameters\":{\"ap\":{\"type\":\"Bool\",\"defaultValue\":\"dataqksa\"},\"benwsdfp\":{\"type\":\"SecureString\",\"defaultValue\":\"datacit\"},\"pmvzpireszya\":{\"type\":\"Int\",\"defaultValue\":\"dataahlfrcqk\"},\"cjjlwkyeahhhut\":{\"type\":\"Float\",\"defaultValue\":\"datamlbmfggeokfe\"}},\"annotations\":[\"datanrfcqu\",\"datam\",\"dataihpinow\"],\"folder\":{\"name\":\"jpxp\"},\"\":{\"lgbbfjmdgjvxlh\":\"datadwyqqidqi\",\"eftyaphqeofytl\":\"datapm\",\"qvjfdgfqpmquxpjh\":\"datanlowmcmcqixuanc\",\"dcio\":\"datafaar\"}}")
.toObject(DynamicsCrmEntityDataset.class);
- Assertions.assertEquals("btxsytrtexeg", model.description());
- Assertions.assertEquals("sb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("m").type());
- Assertions.assertEquals("fbkmvldzmxojzsv", model.folder().name());
+ Assertions.assertEquals("nn", model.description());
+ Assertions.assertEquals("hogalg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("ap").type());
+ Assertions.assertEquals("jpxp", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DynamicsCrmEntityDataset model = new DynamicsCrmEntityDataset().withDescription("btxsytrtexeg")
- .withStructure("datarqjywiwhvycfjn")
- .withSchema("datandiloqkajwjuria")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("sb")
- .withParameters(mapOf("knjxizbaxdy", "dataanhz", "xfexwacy", "datazkz", "kfevui", "datajmlxppdnd",
- "ibfkcjytq", "datau")))
- .withParameters(
- mapOf("m", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqqfopvno")))
- .withAnnotations(Arrays.asList("datasfhoxqlyo"))
- .withFolder(new DatasetFolder().withName("fbkmvldzmxojzsv"))
- .withEntityName("datafkiikgpruccwm");
+ DynamicsCrmEntityDataset model
+ = new DynamicsCrmEntityDataset().withDescription("nn")
+ .withStructure("dataxqhpjhuboh")
+ .withSchema("datazgaybvr")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hogalg")
+ .withParameters(mapOf("pamqxfcssanybz", "datafmzvztaue", "svcdhlywkh", "dataghvdfeumy",
+ "nzxezriwgo", "dataokj")))
+ .withParameters(mapOf("ap",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataqksa"), "benwsdfp",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datacit"),
+ "pmvzpireszya",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataahlfrcqk"),
+ "cjjlwkyeahhhut",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datamlbmfggeokfe")))
+ .withAnnotations(Arrays.asList("datanrfcqu", "datam", "dataihpinow"))
+ .withFolder(new DatasetFolder().withName("jpxp"))
+ .withEntityName("dataeepfh");
model = BinaryData.fromObject(model).toObject(DynamicsCrmEntityDataset.class);
- Assertions.assertEquals("btxsytrtexeg", model.description());
- Assertions.assertEquals("sb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("m").type());
- Assertions.assertEquals("fbkmvldzmxojzsv", model.folder().name());
+ Assertions.assertEquals("nn", model.description());
+ Assertions.assertEquals("hogalg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("ap").type());
+ Assertions.assertEquals("jpxp", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTypePropertiesTests.java
index 74c467d2faf6..eb9c451be676 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmEntityDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class DynamicsCrmEntityDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- DynamicsCrmEntityDatasetTypeProperties model = BinaryData.fromString("{\"entityName\":\"dataykkbxktxbbwl\"}")
+ DynamicsCrmEntityDatasetTypeProperties model = BinaryData.fromString("{\"entityName\":\"dataufzg\"}")
.toObject(DynamicsCrmEntityDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
DynamicsCrmEntityDatasetTypeProperties model
- = new DynamicsCrmEntityDatasetTypeProperties().withEntityName("dataykkbxktxbbwl");
+ = new DynamicsCrmEntityDatasetTypeProperties().withEntityName("dataufzg");
model = BinaryData.fromObject(model).toObject(DynamicsCrmEntityDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmSourceTests.java
index f42f51317e09..ded7f0c6db5c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsCrmSourceTests.java
@@ -11,18 +11,18 @@ public final class DynamicsCrmSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DynamicsCrmSource model = BinaryData.fromString(
- "{\"type\":\"DynamicsCrmSource\",\"query\":\"datazuzvbqbroyrw\",\"additionalColumns\":\"databbfweozkbok\",\"sourceRetryCount\":\"datasu\",\"sourceRetryWait\":\"datacslzca\",\"maxConcurrentConnections\":\"datad\",\"disableMetricsCollection\":\"datafwkpupbsgfnqtxl\",\"\":{\"cist\":\"dataviklxsgstunsa\",\"ajkodpz\":\"databehkb\",\"faas\":\"datatgsazwx\",\"cdl\":\"datahasjbuhz\"}}")
+ "{\"type\":\"DynamicsCrmSource\",\"query\":\"datauutkwwtymbc\",\"additionalColumns\":\"datawsyfsgikgcbjclf\",\"sourceRetryCount\":\"datafdsatrzqmtuxwtda\",\"sourceRetryWait\":\"databifktnxugiorb\",\"maxConcurrentConnections\":\"dataeyrnbubyabtowbu\",\"disableMetricsCollection\":\"datalwbgvzuxfsmf\",\"\":{\"vnoylmfjylh\":\"datauoqpzw\"}}")
.toObject(DynamicsCrmSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DynamicsCrmSource model = new DynamicsCrmSource().withSourceRetryCount("datasu")
- .withSourceRetryWait("datacslzca")
- .withMaxConcurrentConnections("datad")
- .withDisableMetricsCollection("datafwkpupbsgfnqtxl")
- .withQuery("datazuzvbqbroyrw")
- .withAdditionalColumns("databbfweozkbok");
+ DynamicsCrmSource model = new DynamicsCrmSource().withSourceRetryCount("datafdsatrzqmtuxwtda")
+ .withSourceRetryWait("databifktnxugiorb")
+ .withMaxConcurrentConnections("dataeyrnbubyabtowbu")
+ .withDisableMetricsCollection("datalwbgvzuxfsmf")
+ .withQuery("datauutkwwtymbc")
+ .withAdditionalColumns("datawsyfsgikgcbjclf");
model = BinaryData.fromObject(model).toObject(DynamicsCrmSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTests.java
index b547b2e338e9..04be415dad73 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTests.java
@@ -19,35 +19,37 @@ public final class DynamicsEntityDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DynamicsEntityDataset model = BinaryData.fromString(
- "{\"type\":\"DynamicsEntity\",\"typeProperties\":{\"entityName\":\"datam\"},\"description\":\"bvvcpw\",\"structure\":\"datasuspnhmzy\",\"schema\":\"datafetev\",\"linkedServiceName\":{\"referenceName\":\"ntfknwacycsyo\",\"parameters\":{\"xrmhnmizhvprh\":\"datakhfhfsatvc\",\"lobzgott\":\"dataqwcublehhk\"}},\"parameters\":{\"mtbtdvucfvvra\":{\"type\":\"Object\",\"defaultValue\":\"datazigh\"},\"bwkdwjyjiznioroo\":{\"type\":\"Object\",\"defaultValue\":\"dataurdeewlsuxp\"},\"uftrni\":{\"type\":\"SecureString\",\"defaultValue\":\"datataspmcrei\"}},\"annotations\":[\"datainuwqxungrob\"],\"folder\":{\"name\":\"msxjwdylwxm\"},\"\":{\"ugeerclbltbhpwac\":\"dataow\"}}")
+ "{\"type\":\"DynamicsEntity\",\"typeProperties\":{\"entityName\":\"datab\"},\"description\":\"cjy\",\"structure\":\"datadcizeqqfop\",\"schema\":\"dataopmotdsf\",\"linkedServiceName\":{\"referenceName\":\"o\",\"parameters\":{\"ldzmxojzsvmaigb\":\"datayoazyfbkm\"}},\"parameters\":{\"ihba\":{\"type\":\"String\",\"defaultValue\":\"dataejthgeecbpergwlc\"},\"jixiujzkc\":{\"type\":\"String\",\"defaultValue\":\"datasokknpugzjwdizc\"},\"w\":{\"type\":\"String\",\"defaultValue\":\"datagkr\"},\"okn\":{\"type\":\"Int\",\"defaultValue\":\"datakkbxktxbbwlmnw\"}},\"annotations\":[\"dataddlggb\",\"dataa\"],\"folder\":{\"name\":\"zubak\"},\"\":{\"ffetp\":\"datavggcmfn\",\"wewzlscgsme\":\"datami\",\"thhx\":\"datanqvxgvohd\"}}")
.toObject(DynamicsEntityDataset.class);
- Assertions.assertEquals("bvvcpw", model.description());
- Assertions.assertEquals("ntfknwacycsyo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("mtbtdvucfvvra").type());
- Assertions.assertEquals("msxjwdylwxm", model.folder().name());
+ Assertions.assertEquals("cjy", model.description());
+ Assertions.assertEquals("o", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("ihba").type());
+ Assertions.assertEquals("zubak", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DynamicsEntityDataset model = new DynamicsEntityDataset().withDescription("bvvcpw")
- .withStructure("datasuspnhmzy")
- .withSchema("datafetev")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ntfknwacycsyo")
- .withParameters(mapOf("xrmhnmizhvprh", "datakhfhfsatvc", "lobzgott", "dataqwcublehhk")))
- .withParameters(mapOf("mtbtdvucfvvra",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datazigh"),
- "bwkdwjyjiznioroo",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataurdeewlsuxp"),
- "uftrni",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datataspmcrei")))
- .withAnnotations(Arrays.asList("datainuwqxungrob"))
- .withFolder(new DatasetFolder().withName("msxjwdylwxm"))
- .withEntityName("datam");
+ DynamicsEntityDataset model
+ = new DynamicsEntityDataset().withDescription("cjy")
+ .withStructure("datadcizeqqfop")
+ .withSchema("dataopmotdsf")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("o")
+ .withParameters(mapOf("ldzmxojzsvmaigb", "datayoazyfbkm")))
+ .withParameters(mapOf("ihba",
+ new ParameterSpecification().withType(ParameterType.STRING)
+ .withDefaultValue("dataejthgeecbpergwlc"),
+ "jixiujzkc",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datasokknpugzjwdizc"),
+ "w", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datagkr"), "okn",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datakkbxktxbbwlmnw")))
+ .withAnnotations(Arrays.asList("dataddlggb", "dataa"))
+ .withFolder(new DatasetFolder().withName("zubak"))
+ .withEntityName("datab");
model = BinaryData.fromObject(model).toObject(DynamicsEntityDataset.class);
- Assertions.assertEquals("bvvcpw", model.description());
- Assertions.assertEquals("ntfknwacycsyo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("mtbtdvucfvvra").type());
- Assertions.assertEquals("msxjwdylwxm", model.folder().name());
+ Assertions.assertEquals("cjy", model.description());
+ Assertions.assertEquals("o", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("ihba").type());
+ Assertions.assertEquals("zubak", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTypePropertiesTests.java
index c46330a0b2b1..713752bdd943 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsEntityDatasetTypePropertiesTests.java
@@ -10,14 +10,13 @@
public final class DynamicsEntityDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- DynamicsEntityDatasetTypeProperties model = BinaryData.fromString("{\"entityName\":\"dataeurjwmvwry\"}")
- .toObject(DynamicsEntityDatasetTypeProperties.class);
+ DynamicsEntityDatasetTypeProperties model
+ = BinaryData.fromString("{\"entityName\":\"dataev\"}").toObject(DynamicsEntityDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DynamicsEntityDatasetTypeProperties model
- = new DynamicsEntityDatasetTypeProperties().withEntityName("dataeurjwmvwry");
+ DynamicsEntityDatasetTypeProperties model = new DynamicsEntityDatasetTypeProperties().withEntityName("dataev");
model = BinaryData.fromObject(model).toObject(DynamicsEntityDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsSourceTests.java
index 7e206f376327..f4410d39ca20 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/DynamicsSourceTests.java
@@ -11,18 +11,18 @@ public final class DynamicsSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
DynamicsSource model = BinaryData.fromString(
- "{\"type\":\"DynamicsSource\",\"query\":\"datarjuiuzl\",\"additionalColumns\":\"datahzihlzljqcmmgsm\",\"sourceRetryCount\":\"datajunqwkjfmtuybdzr\",\"sourceRetryWait\":\"datackxennzowguirh\",\"maxConcurrentConnections\":\"datajpw\",\"disableMetricsCollection\":\"datamktpykoicpk\",\"\":{\"jaof\":\"dataqfdtbao\",\"rwsj\":\"datacvhhrgvkuuikrsie\",\"vygrfyyknxuacfm\":\"datadxenxjvapdqg\",\"kt\":\"dataynlcimjmurocryfu\"}}")
+ "{\"type\":\"DynamicsSource\",\"query\":\"datadhdtt\",\"additionalColumns\":\"datakeculxvkuxvccpda\",\"sourceRetryCount\":\"dataasi\",\"sourceRetryWait\":\"datatyvvgxe\",\"maxConcurrentConnections\":\"dataqoswjwbh\",\"disableMetricsCollection\":\"datawbchybne\",\"\":{\"jcywyrzxipxhl\":\"dataeikadhusgxkbg\",\"avxgmogcnwxk\":\"dataxkviyjruqyej\",\"thnlceggyqlvn\":\"dataqxpnjqtzdahv\"}}")
.toObject(DynamicsSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- DynamicsSource model = new DynamicsSource().withSourceRetryCount("datajunqwkjfmtuybdzr")
- .withSourceRetryWait("datackxennzowguirh")
- .withMaxConcurrentConnections("datajpw")
- .withDisableMetricsCollection("datamktpykoicpk")
- .withQuery("datarjuiuzl")
- .withAdditionalColumns("datahzihlzljqcmmgsm");
+ DynamicsSource model = new DynamicsSource().withSourceRetryCount("dataasi")
+ .withSourceRetryWait("datatyvvgxe")
+ .withMaxConcurrentConnections("dataqoswjwbh")
+ .withDisableMetricsCollection("datawbchybne")
+ .withQuery("datadhdtt")
+ .withAdditionalColumns("datakeculxvkuxvccpda");
model = BinaryData.fromObject(model).toObject(DynamicsSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaObjectDatasetTests.java
index a4db2989aac4..2beadd771f50 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaObjectDatasetTests.java
@@ -19,35 +19,33 @@ public final class EloquaObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
EloquaObjectDataset model = BinaryData.fromString(
- "{\"type\":\"EloquaObject\",\"typeProperties\":{\"tableName\":\"dataqejex\"},\"description\":\"lhuhdkubgyw\",\"structure\":\"datarklpdyehjrwcflv\",\"schema\":\"dataocaywmfvuhz\",\"linkedServiceName\":{\"referenceName\":\"olhve\",\"parameters\":{\"ymlhklmnjqzm\":\"datagsfmhwdxqu\",\"bthb\":\"dataynhitrnwqgq\"}},\"parameters\":{\"ywzrqeiadd\":{\"type\":\"Bool\",\"defaultValue\":\"datarjocogwfv\"},\"z\":{\"type\":\"Int\",\"defaultValue\":\"datauvnlmdcnutiexm\"},\"tfqhhvvwzprjaaai\":{\"type\":\"String\",\"defaultValue\":\"databqvioyn\"},\"cn\":{\"type\":\"String\",\"defaultValue\":\"datatvavlyaqtl\"}},\"annotations\":[\"datafzvz\",\"datazqcrlkorvbzg\",\"datahenfsfyq\"],\"folder\":{\"name\":\"wmh\"},\"\":{\"agwaakktbjort\":\"datafbywjiaaosla\",\"lislxyljzbkd\":\"datatkajqhsnsej\"}}")
+ "{\"type\":\"EloquaObject\",\"typeProperties\":{\"tableName\":\"datao\"},\"description\":\"guhbnhogsezreneg\",\"structure\":\"datadtyzpx\",\"schema\":\"datatwkejmgem\",\"linkedServiceName\":{\"referenceName\":\"dupe\",\"parameters\":{\"mmpkapvnpeukg\":\"datavsdfvhrypez\"}},\"parameters\":{\"omlcsvkt\":{\"type\":\"String\",\"defaultValue\":\"dataeqnit\"},\"fxjtxla\":{\"type\":\"SecureString\",\"defaultValue\":\"datarowsh\"},\"fqdmll\":{\"type\":\"Float\",\"defaultValue\":\"datadyqabjrop\"}},\"annotations\":[\"datajyuwq\",\"datazwgdpvhwiril\",\"datamqtr\"],\"folder\":{\"name\":\"oxdegacdedpkwd\"},\"\":{\"aqermnddlir\":\"datapgdcidp\",\"lsaqifepdureeviv\":\"dataq\",\"xeswctl\":\"dataiglioklsuff\"}}")
.toObject(EloquaObjectDataset.class);
- Assertions.assertEquals("lhuhdkubgyw", model.description());
- Assertions.assertEquals("olhve", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("ywzrqeiadd").type());
- Assertions.assertEquals("wmh", model.folder().name());
+ Assertions.assertEquals("guhbnhogsezreneg", model.description());
+ Assertions.assertEquals("dupe", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("omlcsvkt").type());
+ Assertions.assertEquals("oxdegacdedpkwd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- EloquaObjectDataset model = new EloquaObjectDataset().withDescription("lhuhdkubgyw")
- .withStructure("datarklpdyehjrwcflv")
- .withSchema("dataocaywmfvuhz")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("olhve")
- .withParameters(mapOf("ymlhklmnjqzm", "datagsfmhwdxqu", "bthb", "dataynhitrnwqgq")))
- .withParameters(mapOf("ywzrqeiadd",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datarjocogwfv"), "z",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datauvnlmdcnutiexm"),
- "tfqhhvvwzprjaaai",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("databqvioyn"), "cn",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datatvavlyaqtl")))
- .withAnnotations(Arrays.asList("datafzvz", "datazqcrlkorvbzg", "datahenfsfyq"))
- .withFolder(new DatasetFolder().withName("wmh"))
- .withTableName("dataqejex");
+ EloquaObjectDataset model = new EloquaObjectDataset().withDescription("guhbnhogsezreneg")
+ .withStructure("datadtyzpx")
+ .withSchema("datatwkejmgem")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dupe")
+ .withParameters(mapOf("mmpkapvnpeukg", "datavsdfvhrypez")))
+ .withParameters(mapOf("omlcsvkt",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataeqnit"), "fxjtxla",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datarowsh"),
+ "fqdmll", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datadyqabjrop")))
+ .withAnnotations(Arrays.asList("datajyuwq", "datazwgdpvhwiril", "datamqtr"))
+ .withFolder(new DatasetFolder().withName("oxdegacdedpkwd"))
+ .withTableName("datao");
model = BinaryData.fromObject(model).toObject(EloquaObjectDataset.class);
- Assertions.assertEquals("lhuhdkubgyw", model.description());
- Assertions.assertEquals("olhve", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("ywzrqeiadd").type());
- Assertions.assertEquals("wmh", model.folder().name());
+ Assertions.assertEquals("guhbnhogsezreneg", model.description());
+ Assertions.assertEquals("dupe", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("omlcsvkt").type());
+ Assertions.assertEquals("oxdegacdedpkwd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaSourceTests.java
index c82a40f159cc..1242e2316599 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EloquaSourceTests.java
@@ -11,19 +11,19 @@ public final class EloquaSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
EloquaSource model = BinaryData.fromString(
- "{\"type\":\"EloquaSource\",\"query\":\"dataxtkmknacnfzcy\",\"queryTimeout\":\"datahdjpagwszm\",\"additionalColumns\":\"datagzfeyexbg\",\"sourceRetryCount\":\"datayo\",\"sourceRetryWait\":\"datawigvqgc\",\"maxConcurrentConnections\":\"datacqjg\",\"disableMetricsCollection\":\"dataxpbpj\",\"\":{\"ohehhtl\":\"datanvdabaodiytxq\"}}")
+ "{\"type\":\"EloquaSource\",\"query\":\"datawbqaibkyeysf\",\"queryTimeout\":\"datahdydyybztlylh\",\"additionalColumns\":\"datacjq\",\"sourceRetryCount\":\"datacie\",\"sourceRetryWait\":\"datak\",\"maxConcurrentConnections\":\"dataxf\",\"disableMetricsCollection\":\"datahvecjhbttmhneqd\",\"\":{\"kna\":\"dataeyxxidabqla\",\"ljsfcryqrrsjqt\":\"datacseqo\"}}")
.toObject(EloquaSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- EloquaSource model = new EloquaSource().withSourceRetryCount("datayo")
- .withSourceRetryWait("datawigvqgc")
- .withMaxConcurrentConnections("datacqjg")
- .withDisableMetricsCollection("dataxpbpj")
- .withQueryTimeout("datahdjpagwszm")
- .withAdditionalColumns("datagzfeyexbg")
- .withQuery("dataxtkmknacnfzcy");
+ EloquaSource model = new EloquaSource().withSourceRetryCount("datacie")
+ .withSourceRetryWait("datak")
+ .withMaxConcurrentConnections("dataxf")
+ .withDisableMetricsCollection("datahvecjhbttmhneqd")
+ .withQueryTimeout("datahdydyybztlylh")
+ .withAdditionalColumns("datacjq")
+ .withQuery("datawbqaibkyeysf");
model = BinaryData.fromObject(model).toObject(EloquaSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EntityReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EntityReferenceTests.java
index 871cf435693b..928e7cc1d8c3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EntityReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EntityReferenceTests.java
@@ -12,19 +12,20 @@
public final class EntityReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- EntityReference model = BinaryData.fromString("{\"type\":\"LinkedServiceReference\",\"referenceName\":\"miy\"}")
- .toObject(EntityReference.class);
- Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE, model.type());
- Assertions.assertEquals("miy", model.referenceName());
+ EntityReference model
+ = BinaryData.fromString("{\"type\":\"IntegrationRuntimeReference\",\"referenceName\":\"enintz\"}")
+ .toObject(EntityReference.class);
+ Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE, model.type());
+ Assertions.assertEquals("enintz", model.referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
EntityReference model
- = new EntityReference().withType(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE)
- .withReferenceName("miy");
+ = new EntityReference().withType(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE)
+ .withReferenceName("enintz");
model = BinaryData.fromObject(model).toObject(EntityReference.class);
- Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE, model.type());
- Assertions.assertEquals("miy", model.referenceName());
+ Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE, model.type());
+ Assertions.assertEquals("enintz", model.referenceName());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTests.java
index fb648d2c7c36..2110abbce7e3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTests.java
@@ -12,18 +12,18 @@ public final class EnvironmentVariableSetupTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
EnvironmentVariableSetup model = BinaryData.fromString(
- "{\"type\":\"EnvironmentVariableSetup\",\"typeProperties\":{\"variableName\":\"odbl\",\"variableValue\":\"pqr\"}}")
+ "{\"type\":\"EnvironmentVariableSetup\",\"typeProperties\":{\"variableName\":\"dwdmuvya\",\"variableValue\":\"rbqpwx\"}}")
.toObject(EnvironmentVariableSetup.class);
- Assertions.assertEquals("odbl", model.variableName());
- Assertions.assertEquals("pqr", model.variableValue());
+ Assertions.assertEquals("dwdmuvya", model.variableName());
+ Assertions.assertEquals("rbqpwx", model.variableValue());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
EnvironmentVariableSetup model
- = new EnvironmentVariableSetup().withVariableName("odbl").withVariableValue("pqr");
+ = new EnvironmentVariableSetup().withVariableName("dwdmuvya").withVariableValue("rbqpwx");
model = BinaryData.fromObject(model).toObject(EnvironmentVariableSetup.class);
- Assertions.assertEquals("odbl", model.variableName());
- Assertions.assertEquals("pqr", model.variableValue());
+ Assertions.assertEquals("dwdmuvya", model.variableName());
+ Assertions.assertEquals("rbqpwx", model.variableValue());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTypePropertiesTests.java
index 7e637d0e0ae3..6f6e84b47934 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/EnvironmentVariableSetupTypePropertiesTests.java
@@ -12,18 +12,19 @@ public final class EnvironmentVariableSetupTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
EnvironmentVariableSetupTypeProperties model
- = BinaryData.fromString("{\"variableName\":\"cz\",\"variableValue\":\"tniwfcu\"}")
+ = BinaryData.fromString("{\"variableName\":\"blzrmiukothyfjbp\",\"variableValue\":\"hdhfrvsizfwgn\"}")
.toObject(EnvironmentVariableSetupTypeProperties.class);
- Assertions.assertEquals("cz", model.variableName());
- Assertions.assertEquals("tniwfcu", model.variableValue());
+ Assertions.assertEquals("blzrmiukothyfjbp", model.variableName());
+ Assertions.assertEquals("hdhfrvsizfwgn", model.variableValue());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
EnvironmentVariableSetupTypeProperties model
- = new EnvironmentVariableSetupTypeProperties().withVariableName("cz").withVariableValue("tniwfcu");
+ = new EnvironmentVariableSetupTypeProperties().withVariableName("blzrmiukothyfjbp")
+ .withVariableValue("hdhfrvsizfwgn");
model = BinaryData.fromObject(model).toObject(EnvironmentVariableSetupTypeProperties.class);
- Assertions.assertEquals("cz", model.variableName());
- Assertions.assertEquals("tniwfcu", model.variableValue());
+ Assertions.assertEquals("blzrmiukothyfjbp", model.variableName());
+ Assertions.assertEquals("hdhfrvsizfwgn", model.variableValue());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExcelSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExcelSourceTests.java
index 1ff2ad1a127c..66c1db347f80 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExcelSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExcelSourceTests.java
@@ -14,20 +14,20 @@ public final class ExcelSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExcelSource model = BinaryData.fromString(
- "{\"type\":\"ExcelSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datailwisqxzpzitust\",\"disableMetricsCollection\":\"datarfvogknocsh\",\"\":{\"rbrv\":\"datajqtuzb\",\"rhccdgunsjssreo\":\"datahfjqpxydpamctzm\",\"ppbghyekggoaw\":\"datasgkouenpgkxyr\",\"wqsgyrznostngxvr\":\"dataqvuwsq\"}},\"additionalColumns\":\"dataizjnkgdsursumb\",\"sourceRetryCount\":\"datarkbkqp\",\"sourceRetryWait\":\"dataoxshxumuuy\",\"maxConcurrentConnections\":\"dataolrufv\",\"disableMetricsCollection\":\"datablbqxlsam\",\"\":{\"gvmowyzxqhuhmldh\":\"dataqhwsojnbb\"}}")
+ "{\"type\":\"ExcelSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datadvhokxxfawhoos\",\"disableMetricsCollection\":\"dataolhhvmfoejbgi\",\"\":{\"fie\":\"datapelnud\",\"jllfgmdoaihl\":\"dataxxorsdvuirqfk\",\"cv\":\"datarsqcivmirybwga\"}},\"additionalColumns\":\"datay\",\"sourceRetryCount\":\"datamazgtbyn\",\"sourceRetryWait\":\"datahcawexgeqojzvu\",\"maxConcurrentConnections\":\"dataxkojjp\",\"disableMetricsCollection\":\"dataobuovsvwnpcxdk\",\"\":{\"devotucnzbpocum\":\"dataparyubnyhmlp\",\"t\":\"dataz\"}}")
.toObject(ExcelSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ExcelSource model = new ExcelSource().withSourceRetryCount("datarkbkqp")
- .withSourceRetryWait("dataoxshxumuuy")
- .withMaxConcurrentConnections("dataolrufv")
- .withDisableMetricsCollection("datablbqxlsam")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datailwisqxzpzitust")
- .withDisableMetricsCollection("datarfvogknocsh")
+ ExcelSource model = new ExcelSource().withSourceRetryCount("datamazgtbyn")
+ .withSourceRetryWait("datahcawexgeqojzvu")
+ .withMaxConcurrentConnections("dataxkojjp")
+ .withDisableMetricsCollection("dataobuovsvwnpcxdk")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datadvhokxxfawhoos")
+ .withDisableMetricsCollection("dataolhhvmfoejbgi")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
- .withAdditionalColumns("dataizjnkgdsursumb");
+ .withAdditionalColumns("datay");
model = BinaryData.fromObject(model).toObject(ExcelSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecuteDataFlowActivityTypePropertiesComputeTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecuteDataFlowActivityTypePropertiesComputeTests.java
index fa4512aa2d28..844e22cc531c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecuteDataFlowActivityTypePropertiesComputeTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecuteDataFlowActivityTypePropertiesComputeTests.java
@@ -11,15 +11,15 @@ public final class ExecuteDataFlowActivityTypePropertiesComputeTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExecuteDataFlowActivityTypePropertiesCompute model
- = BinaryData.fromString("{\"computeType\":\"datawjnvhuswmwvqb\",\"coreCount\":\"datazjmfqusp\"}")
+ = BinaryData.fromString("{\"computeType\":\"datanma\",\"coreCount\":\"datasuqarmijuldojo\"}")
.toObject(ExecuteDataFlowActivityTypePropertiesCompute.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
ExecuteDataFlowActivityTypePropertiesCompute model
- = new ExecuteDataFlowActivityTypePropertiesCompute().withComputeType("datawjnvhuswmwvqb")
- .withCoreCount("datazjmfqusp");
+ = new ExecuteDataFlowActivityTypePropertiesCompute().withComputeType("datanma")
+ .withCoreCount("datasuqarmijuldojo");
model = BinaryData.fromObject(model).toObject(ExecuteDataFlowActivityTypePropertiesCompute.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityPolicyTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityPolicyTests.java
index 4b9d9b0342b1..6737a684c02f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityPolicyTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityPolicyTests.java
@@ -14,7 +14,7 @@ public final class ExecutePipelineActivityPolicyTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExecutePipelineActivityPolicy model = BinaryData.fromString(
- "{\"secureInput\":false,\"\":{\"nlfzq\":\"dataomtzpukmxgslzb\",\"wzesejdcpcpeu\":\"datamxuo\",\"jrptltytbqhejhn\":\"databofzmvtwyjc\"}}")
+ "{\"secureInput\":false,\"\":{\"rbmfobtmljobg\":\"dataqgwvxwqqmv\",\"hebyc\":\"dataoyownygbralc\",\"dp\":\"datawegt\"}}")
.toObject(ExecutePipelineActivityPolicy.class);
Assertions.assertEquals(false, model.secureInput());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTests.java
index 804bd0b7abd3..32e8aa78d46f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTests.java
@@ -22,52 +22,64 @@ public final class ExecutePipelineActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExecutePipelineActivity model = BinaryData.fromString(
- "{\"type\":\"ExecutePipeline\",\"policy\":{\"secureInput\":true,\"\":{\"atpdxpo\":\"datatqvbahi\",\"chnhj\":\"dataogvpsmx\",\"mlplqgp\":\"dataaqpwxuyik\",\"zb\":\"datakynkkezkvnlvwts\"}},\"typeProperties\":{\"pipeline\":{\"referenceName\":\"gvezhimx\",\"name\":\"qwlxkyoysyutn\"},\"parameters\":{\"xmyblway\":\"datazkovtjnmcaprxh\",\"wyfy\":\"datapaggkrumpu\"},\"waitOnCompletion\":false},\"name\":\"boipxh\",\"description\":\"icwvhjdrvj\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ooytilsmise\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Failed\"],\"\":{\"crzgluqacebcn\":\"dataqu\",\"aumjuruspflvgl\":\"datazh\",\"ekbrqg\":\"datawkgcpfz\"}},{\"activity\":\"vxwq\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"ob\":\"datamfobtml\",\"cwhebyczweg\":\"datauoyownygbra\",\"razqxxvksqifr\":\"datazd\",\"cmegoll\":\"datamidvturdgl\"}}],\"userProperties\":[{\"name\":\"pryhz\",\"value\":\"datawxuizakejom\"}],\"\":{\"bqii\":\"dataxjhrzgnfqqlgqez\",\"krarzkzatznvye\":\"dataeoace\"}}")
+ "{\"type\":\"ExecutePipeline\",\"policy\":{\"secureInput\":false,\"\":{\"bwpdvedm\":\"datascmfnk\",\"onkfb\":\"datackbgxgykxszet\",\"szn\":\"datawfkczldepz\"}},\"typeProperties\":{\"pipeline\":{\"referenceName\":\"wdcisceiauoy\",\"name\":\"dnxawf\"},\"parameters\":{\"xjiz\":\"datambvccuikpavi\",\"tltcrtmebrssrl\":\"datajsuiou\"},\"waitOnCompletion\":false},\"name\":\"qpth\",\"description\":\"j\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"nsogdvhqqxggncg\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"brhkdemax\":\"dataxcjqrvpgukscr\",\"gkcac\":\"dataaj\",\"jgageyxajk\":\"datas\",\"gfxwynzbeemlsrtg\":\"datazkzprjqb\"}},{\"activity\":\"gcmutuk\",\"dependencyConditions\":[\"Completed\",\"Failed\"],\"\":{\"fdrxy\":\"dataufuhbdm\",\"tpdxpoxogvpsmx\":\"datajjqctqvbahii\",\"aqpwxuyik\":\"datachnhj\"}},{\"activity\":\"mlplqgp\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Skipped\",\"Succeeded\"],\"\":{\"zhi\":\"datakvnlvwtslzblgv\"}},{\"activity\":\"xiyqwlx\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Failed\"],\"\":{\"edz\":\"datatn\",\"nmcaprxhixmybl\":\"dataovt\"}}],\"userProperties\":[{\"name\":\"u\",\"value\":\"dataaggkrumpunw\"},{\"name\":\"fyvhcbo\",\"value\":\"datapxh\"},{\"name\":\"hi\",\"value\":\"datawvhjdrvjktv\"}],\"\":{\"isew\":\"datanooytils\",\"zgluqacebcnhz\":\"dataljmmoquic\",\"lvwkgcpfz\":\"datasaumjuruspflv\"}}")
.toObject(ExecutePipelineActivity.class);
- Assertions.assertEquals("boipxh", model.name());
- Assertions.assertEquals("icwvhjdrvj", model.description());
+ Assertions.assertEquals("qpth", model.name());
+ Assertions.assertEquals("j", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ooytilsmise", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("pryhz", model.userProperties().get(0).name());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals("gvezhimx", model.pipeline().referenceName());
- Assertions.assertEquals("qwlxkyoysyutn", model.pipeline().name());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("nsogdvhqqxggncg", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("u", model.userProperties().get(0).name());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals("wdcisceiauoy", model.pipeline().referenceName());
+ Assertions.assertEquals("dnxawf", model.pipeline().name());
Assertions.assertEquals(false, model.waitOnCompletion());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ExecutePipelineActivity model = new ExecutePipelineActivity().withName("boipxh")
- .withDescription("icwvhjdrvj")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ooytilsmise")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED,
- DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("vxwq")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("pryhz").withValue("datawxuizakejom")))
- .withPolicy(new ExecutePipelineActivityPolicy().withSecureInput(true).withAdditionalProperties(mapOf()))
- .withPipeline(new PipelineReference().withReferenceName("gvezhimx").withName("qwlxkyoysyutn"))
- .withParameters(mapOf("xmyblway", "datazkovtjnmcaprxh", "wyfy", "datapaggkrumpu"))
- .withWaitOnCompletion(false);
+ ExecutePipelineActivity model
+ = new ExecutePipelineActivity().withName("qpth")
+ .withDescription("j")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("nsogdvhqqxggncg")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("gcmutuk")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("mlplqgp")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED,
+ DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("xiyqwlx")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.COMPLETED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("u").withValue("dataaggkrumpunw"),
+ new UserProperty().withName("fyvhcbo").withValue("datapxh"),
+ new UserProperty().withName("hi").withValue("datawvhjdrvjktv")))
+ .withPolicy(
+ new ExecutePipelineActivityPolicy().withSecureInput(false).withAdditionalProperties(mapOf()))
+ .withPipeline(new PipelineReference().withReferenceName("wdcisceiauoy").withName("dnxawf"))
+ .withParameters(mapOf("xjiz", "datambvccuikpavi", "tltcrtmebrssrl", "datajsuiou"))
+ .withWaitOnCompletion(false);
model = BinaryData.fromObject(model).toObject(ExecutePipelineActivity.class);
- Assertions.assertEquals("boipxh", model.name());
- Assertions.assertEquals("icwvhjdrvj", model.description());
+ Assertions.assertEquals("qpth", model.name());
+ Assertions.assertEquals("j", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ooytilsmise", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("pryhz", model.userProperties().get(0).name());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals("gvezhimx", model.pipeline().referenceName());
- Assertions.assertEquals("qwlxkyoysyutn", model.pipeline().name());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("nsogdvhqqxggncg", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("u", model.userProperties().get(0).name());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals("wdcisceiauoy", model.pipeline().referenceName());
+ Assertions.assertEquals("dnxawf", model.pipeline().name());
Assertions.assertEquals(false, model.waitOnCompletion());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTypePropertiesTests.java
index daffae80267f..8e5d699b3a48 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutePipelineActivityTypePropertiesTests.java
@@ -15,23 +15,23 @@ public final class ExecutePipelineActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExecutePipelineActivityTypeProperties model = BinaryData.fromString(
- "{\"pipeline\":{\"referenceName\":\"jlbygq\",\"name\":\"eeuuur\"},\"parameters\":{\"wvygquiwcfqzo\":\"datalx\",\"irqkskyyam\":\"datagwwdevqmtejhvggy\",\"lmibvczdj\":\"datamimsyiwcdwqjbrrx\",\"lvlfkwdtsbjmc\":\"datao\"},\"waitOnCompletion\":true}")
+ "{\"pipeline\":{\"referenceName\":\"az\",\"name\":\"xvksqifrgmid\"},\"parameters\":{\"l\":\"datardglecmeg\",\"ryhztwxuizakejo\":\"datadlt\",\"gqezgbqiiweoa\":\"datajnlxjhrzgnfqq\"},\"waitOnCompletion\":true}")
.toObject(ExecutePipelineActivityTypeProperties.class);
- Assertions.assertEquals("jlbygq", model.pipeline().referenceName());
- Assertions.assertEquals("eeuuur", model.pipeline().name());
+ Assertions.assertEquals("az", model.pipeline().referenceName());
+ Assertions.assertEquals("xvksqifrgmid", model.pipeline().name());
Assertions.assertEquals(true, model.waitOnCompletion());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
ExecutePipelineActivityTypeProperties model = new ExecutePipelineActivityTypeProperties()
- .withPipeline(new PipelineReference().withReferenceName("jlbygq").withName("eeuuur"))
- .withParameters(mapOf("wvygquiwcfqzo", "datalx", "irqkskyyam", "datagwwdevqmtejhvggy", "lmibvczdj",
- "datamimsyiwcdwqjbrrx", "lvlfkwdtsbjmc", "datao"))
+ .withPipeline(new PipelineReference().withReferenceName("az").withName("xvksqifrgmid"))
+ .withParameters(
+ mapOf("l", "datardglecmeg", "ryhztwxuizakejo", "datadlt", "gqezgbqiiweoa", "datajnlxjhrzgnfqq"))
.withWaitOnCompletion(true);
model = BinaryData.fromObject(model).toObject(ExecutePipelineActivityTypeProperties.class);
- Assertions.assertEquals("jlbygq", model.pipeline().referenceName());
- Assertions.assertEquals("eeuuur", model.pipeline().name());
+ Assertions.assertEquals("az", model.pipeline().referenceName());
+ Assertions.assertEquals("xvksqifrgmid", model.pipeline().name());
Assertions.assertEquals(true, model.waitOnCompletion());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutionActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutionActivityTests.java
index c875cf6d6ac4..349fb1ac4c5f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutionActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExecutionActivityTests.java
@@ -22,58 +22,50 @@ public final class ExecutionActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExecutionActivity model = BinaryData.fromString(
- "{\"type\":\"Execution\",\"linkedServiceName\":{\"referenceName\":\"ouplamdgf\",\"parameters\":{\"cxl\":\"datanisoorwfdtjpsjwl\"}},\"policy\":{\"timeout\":\"datacdrgt\",\"retry\":\"dataoouocafaxvhjrpb\",\"retryIntervalInSeconds\":1593376991,\"secureInput\":true,\"secureOutput\":false,\"\":{\"lbyjahbzbtl\":\"datanenjtxuuwdmrqa\"}},\"name\":\"acbwmvphmjyzice\",\"description\":\"lazcgwnibnduqgj\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"ocrwuhumgwspugn\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Completed\"],\"\":{\"koxqbozezx\":\"dataud\",\"qllt\":\"datawinrgukqobo\"}},{\"activity\":\"lqufkrnrbnjkcol\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Completed\",\"Succeeded\"],\"\":{\"v\":\"dataawdmdikufz\"}}],\"userProperties\":[{\"name\":\"jzofyldxkzhvfo\",\"value\":\"datacvnhpebuiywkysgq\"},{\"name\":\"cbeauvld\",\"value\":\"datadnmguifqj\"},{\"name\":\"oxzxbljpzauug\",\"value\":\"dataarfumitjaiis\"}],\"\":{\"y\":\"datafdyb\",\"rwrylcttvxk\":\"databgmjrvrsqrjco\",\"jbl\":\"datagffpvvqwvvnxoqaa\",\"tsztxoswvfrym\":\"dataqwwtevfeugc\"}}")
+ "{\"type\":\"Execution\",\"linkedServiceName\":{\"referenceName\":\"behv\",\"parameters\":{\"zgnyfhqyli\":\"datahltnds\",\"eninaf\":\"datagnbhz\",\"tzkcol\":\"dataagaocv\"}},\"policy\":{\"timeout\":\"dataspqvxzicurufn\",\"retry\":\"databvdl\",\"retryIntervalInSeconds\":1565631474,\"secureInput\":true,\"secureOutput\":false,\"\":{\"xranbtqej\":\"dataenvxuhz\",\"ajbcbrtiqpjlakam\":\"dataqghgadrvxbcye\",\"icrqxqjzmosmlhc\":\"datadql\",\"pkpmdlt\":\"datapfgtnsxdjhztn\"}},\"name\":\"mfhde\",\"description\":\"iaaiqyxlromxpe\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"acbtyorlrda\",\"dependencyConditions\":[\"Skipped\",\"Skipped\"],\"\":{\"ygj\":\"databbaxnym\"}}],\"userProperties\":[{\"name\":\"kakgwlqzn\",\"value\":\"databsdgyheyayktutf\"},{\"name\":\"hegoxef\",\"value\":\"dataahmdco\"}],\"\":{\"ihkhjldw\":\"datawgzszjqzmqjhg\",\"bjvmdkgvu\":\"datadqtjhtgnc\"}}")
.toObject(ExecutionActivity.class);
- Assertions.assertEquals("acbwmvphmjyzice", model.name());
- Assertions.assertEquals("lazcgwnibnduqgj", model.description());
+ Assertions.assertEquals("mfhde", model.name());
+ Assertions.assertEquals("iaaiqyxlromxpe", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("ocrwuhumgwspugn", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("acbtyorlrda", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jzofyldxkzhvfo", model.userProperties().get(0).name());
- Assertions.assertEquals("ouplamdgf", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1593376991, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("kakgwlqzn", model.userProperties().get(0).name());
+ Assertions.assertEquals("behv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1565631474, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ExecutionActivity model = new ExecutionActivity().withName("acbwmvphmjyzice")
- .withDescription("lazcgwnibnduqgj")
+ ExecutionActivity model = new ExecutionActivity().withName("mfhde")
+ .withDescription("iaaiqyxlromxpe")
.withState(ActivityState.ACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ocrwuhumgwspugn")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED,
- DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("lqufkrnrbnjkcol")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED,
- DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("jzofyldxkzhvfo").withValue("datacvnhpebuiywkysgq"),
- new UserProperty().withName("cbeauvld").withValue("datadnmguifqj"),
- new UserProperty().withName("oxzxbljpzauug").withValue("dataarfumitjaiis")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ouplamdgf")
- .withParameters(mapOf("cxl", "datanisoorwfdtjpsjwl")))
- .withPolicy(new ActivityPolicy().withTimeout("datacdrgt")
- .withRetry("dataoouocafaxvhjrpb")
- .withRetryIntervalInSeconds(1593376991)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("acbtyorlrda")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("kakgwlqzn").withValue("databsdgyheyayktutf"),
+ new UserProperty().withName("hegoxef").withValue("dataahmdco")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("behv")
+ .withParameters(mapOf("zgnyfhqyli", "datahltnds", "eninaf", "datagnbhz", "tzkcol", "dataagaocv")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataspqvxzicurufn")
+ .withRetry("databvdl")
+ .withRetryIntervalInSeconds(1565631474)
.withSecureInput(true)
.withSecureOutput(false)
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(ExecutionActivity.class);
- Assertions.assertEquals("acbwmvphmjyzice", model.name());
- Assertions.assertEquals("lazcgwnibnduqgj", model.description());
+ Assertions.assertEquals("mfhde", model.name());
+ Assertions.assertEquals("iaaiqyxlromxpe", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("ocrwuhumgwspugn", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("acbtyorlrda", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jzofyldxkzhvfo", model.userProperties().get(0).name());
- Assertions.assertEquals("ouplamdgf", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1593376991, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("kakgwlqzn", model.userProperties().get(0).name());
+ Assertions.assertEquals("behv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1565631474, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
Assertions.assertEquals(false, model.policy().secureOutput());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExportSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExportSettingsTests.java
index 0089f7f64c3e..b1fce8873d7a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExportSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExportSettingsTests.java
@@ -13,7 +13,7 @@ public final class ExportSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExportSettings model = BinaryData.fromString(
- "{\"type\":\"ExportSettings\",\"\":{\"oiumuxna\":\"datayk\",\"hmxz\":\"dataivgmck\",\"biojncgjo\":\"datampoiutaatv\"}}")
+ "{\"type\":\"ExportSettings\",\"\":{\"bf\":\"datandwoyqvcyqjjxhi\",\"birhgjmphyacd\":\"datayuhoxulevp\",\"hljtkuyvytfuq\":\"datajmpnvgkxs\",\"kf\":\"datastqbxpyfawkjei\"}}")
.toObject(ExportSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueByFactoryWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueByFactoryWithResponseMockTests.java
index 0758f927833b..83957af39966 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueByFactoryWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueByFactoryWithResponseMockTests.java
@@ -20,7 +20,7 @@
public final class ExposureControlsGetFeatureValueByFactoryWithResponseMockTests {
@Test
public void testGetFeatureValueByFactoryWithResponse() throws Exception {
- String responseStr = "{\"featureName\":\"bobgwvhdbie\",\"value\":\"y\"}";
+ String responseStr = "{\"featureName\":\"zlvmx\",\"value\":\"pcnm\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -30,8 +30,8 @@ public void testGetFeatureValueByFactoryWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ExposureControlResponse response = manager.exposureControls()
- .getFeatureValueByFactoryWithResponse("mw", "jvuwaqiomdlp",
- new ExposureControlRequest().withFeatureName("fslmtwowmwrn").withFeatureType("wgrtv"),
+ .getFeatureValueByFactoryWithResponse("stqsrtzgvwhj", "uoipstvcqh",
+ new ExposureControlRequest().withFeatureName("j").withFeatureType("okhlopygrsvyjrq"),
com.azure.core.util.Context.NONE)
.getValue();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueWithResponseMockTests.java
index 12d07e1fe6b9..d11564d80438 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsGetFeatureValueWithResponseMockTests.java
@@ -20,7 +20,7 @@
public final class ExposureControlsGetFeatureValueWithResponseMockTests {
@Test
public void testGetFeatureValueWithResponse() throws Exception {
- String responseStr = "{\"featureName\":\"fvjv\",\"value\":\"huvuadpdjovwbhei\"}";
+ String responseStr = "{\"featureName\":\"cdvwnpt\",\"value\":\"iqeaugidsz\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -30,8 +30,8 @@ public void testGetFeatureValueWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ExposureControlResponse response = manager.exposureControls()
- .getFeatureValueWithResponse("wlixh",
- new ExposureControlRequest().withFeatureName("tqsprnh").withFeatureType("fhfjwajsbq"),
+ .getFeatureValueWithResponse("iafgbfkmqhzjsh",
+ new ExposureControlRequest().withFeatureName("jnrjr").withFeatureType("ksleurjynezpew"),
com.azure.core.util.Context.NONE)
.getValue();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsQueryFeatureValuesByFactoryWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsQueryFeatureValuesByFactoryWithResponseMockTests.java
index 5f1a37561bc4..efd878459258 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsQueryFeatureValuesByFactoryWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExposureControlsQueryFeatureValuesByFactoryWithResponseMockTests.java
@@ -23,7 +23,7 @@ public final class ExposureControlsQueryFeatureValuesByFactoryWithResponseMockTe
@Test
public void testQueryFeatureValuesByFactoryWithResponse() throws Exception {
String responseStr
- = "{\"exposureControlResponses\":[{\"featureName\":\"ogmcblwhzvnisinp\",\"value\":\"wwpukabja\"},{\"featureName\":\"hngaczgg\",\"value\":\"aqmuptnhuybtmto\"},{\"featureName\":\"hyozxotwral\",\"value\":\"jzlnrellwf\"}]}";
+ = "{\"exposureControlResponses\":[{\"featureName\":\"tchigubsidwgy\",\"value\":\"ppefsdoodcmjfiey\"},{\"featureName\":\"npqtwohfhscke\",\"value\":\"m\"},{\"featureName\":\"goaxtwtkkmuir\",\"value\":\"oaxstqqjq\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -33,10 +33,9 @@ public void testQueryFeatureValuesByFactoryWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ExposureControlBatchResponse response = manager.exposureControls()
- .queryFeatureValuesByFactoryWithResponse("pay", "aschhfm",
+ .queryFeatureValuesByFactoryWithResponse("syzk", "entiprriqwf",
new ExposureControlBatchRequest().withExposureControlRequests(Arrays.asList(
- new ExposureControlRequest().withFeatureName("dywpptessvmdo").withFeatureType("cvugary"),
- new ExposureControlRequest().withFeatureName("yuukhssretugorc").withFeatureType("csevqtd"))),
+ new ExposureControlRequest().withFeatureName("dyingrcjoycqndg").withFeatureType("tzytesz"))),
com.azure.core.util.Context.NONE)
.getValue();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExpressionV2Tests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExpressionV2Tests.java
index c993ecae12c1..14a6e1168be6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExpressionV2Tests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ExpressionV2Tests.java
@@ -14,59 +14,40 @@ public final class ExpressionV2Tests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ExpressionV2 model = BinaryData.fromString(
- "{\"type\":\"Unary\",\"value\":\"axehiegkpukva\",\"operators\":[\"lbqhtiijlikio\",\"dtdekmwzs\"],\"operands\":[{\"type\":\"Binary\",\"value\":\"jsmkhk\",\"operators\":[\"ccd\",\"siizadmbn\",\"yswpnoghkhzwfns\",\"uwttrvgzjfptprfq\"],\"operands\":[{\"type\":\"Binary\",\"value\":\"ndzvtfkdzqt\",\"operators\":[\"yjqbezv\",\"ebdhpizk\",\"qkylmfy\",\"iodcgwbkfcajtxzd\"],\"operands\":[{},{},{},{}]},{\"type\":\"Binary\",\"value\":\"ng\",\"operators\":[\"aexewftqo\",\"fvjfaqah\",\"eskdsbp\"],\"operands\":[{},{},{},{}]},{\"type\":\"Field\",\"value\":\"b\",\"operators\":[\"xjucojzjr\",\"ppvdhklcczgflo\",\"zst\"],\"operands\":[{}]}]},{\"type\":\"Field\",\"value\":\"afrbuvwugww\",\"operators\":[\"xhvesoodxmmty\",\"mejpqxuiodwbla\"],\"operands\":[{\"type\":\"Binary\",\"value\":\"dvceuyw\",\"operators\":[\"t\",\"lcvokvoqjb\",\"dyoc\"],\"operands\":[{},{},{}]}]}]}")
+ "{\"type\":\"Binary\",\"value\":\"cvkmedrkolpneb\",\"operators\":[\"fvkskjd\",\"djxvcxepjfxcmrhi\"],\"operands\":[{\"type\":\"Binary\",\"value\":\"etflirbvqkbxg\",\"operators\":[\"inyursqf\",\"rz\",\"yxmfipvg\"],\"operands\":[{\"type\":\"Field\",\"value\":\"f\",\"operators\":[\"xa\",\"xvftllsu\"],\"operands\":[{},{},{}]}]}]}")
.toObject(ExpressionV2.class);
- Assertions.assertEquals(ExpressionV2Type.UNARY, model.type());
- Assertions.assertEquals("axehiegkpukva", model.value());
- Assertions.assertEquals("lbqhtiijlikio", model.operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.BINARY, model.type());
+ Assertions.assertEquals("cvkmedrkolpneb", model.value());
+ Assertions.assertEquals("fvkskjd", model.operators().get(0));
Assertions.assertEquals(ExpressionV2Type.BINARY, model.operands().get(0).type());
- Assertions.assertEquals("jsmkhk", model.operands().get(0).value());
- Assertions.assertEquals("ccd", model.operands().get(0).operators().get(0));
- Assertions.assertEquals(ExpressionV2Type.BINARY, model.operands().get(0).operands().get(0).type());
- Assertions.assertEquals("ndzvtfkdzqt", model.operands().get(0).operands().get(0).value());
- Assertions.assertEquals("yjqbezv", model.operands().get(0).operands().get(0).operators().get(0));
+ Assertions.assertEquals("etflirbvqkbxg", model.operands().get(0).value());
+ Assertions.assertEquals("inyursqf", model.operands().get(0).operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.FIELD, model.operands().get(0).operands().get(0).type());
+ Assertions.assertEquals("f", model.operands().get(0).operands().get(0).value());
+ Assertions.assertEquals("xa", model.operands().get(0).operands().get(0).operators().get(0));
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ExpressionV2 model = new ExpressionV2().withType(ExpressionV2Type.UNARY)
- .withValue("axehiegkpukva")
- .withOperators(Arrays.asList("lbqhtiijlikio", "dtdekmwzs"))
- .withOperands(Arrays.asList(
- new ExpressionV2().withType(ExpressionV2Type.BINARY)
- .withValue("jsmkhk")
- .withOperators(Arrays.asList("ccd", "siizadmbn", "yswpnoghkhzwfns", "uwttrvgzjfptprfq"))
- .withOperands(Arrays.asList(
- new ExpressionV2().withType(ExpressionV2Type.BINARY)
- .withValue("ndzvtfkdzqt")
- .withOperators(Arrays.asList("yjqbezv", "ebdhpizk", "qkylmfy", "iodcgwbkfcajtxzd"))
- .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(), new ExpressionV2(),
- new ExpressionV2())),
- new ExpressionV2().withType(ExpressionV2Type.BINARY)
- .withValue("ng")
- .withOperators(Arrays.asList("aexewftqo", "fvjfaqah", "eskdsbp"))
- .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(), new ExpressionV2(),
- new ExpressionV2())),
- new ExpressionV2().withType(ExpressionV2Type.FIELD)
- .withValue("b")
- .withOperators(Arrays.asList("xjucojzjr", "ppvdhklcczgflo", "zst"))
- .withOperands(Arrays.asList(new ExpressionV2())))),
- new ExpressionV2().withType(ExpressionV2Type.FIELD)
- .withValue("afrbuvwugww")
- .withOperators(Arrays.asList("xhvesoodxmmty", "mejpqxuiodwbla"))
- .withOperands(Arrays.asList(new ExpressionV2().withType(ExpressionV2Type.BINARY)
- .withValue("dvceuyw")
- .withOperators(Arrays.asList("t", "lcvokvoqjb", "dyoc"))
- .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(), new ExpressionV2()))))));
+ ExpressionV2 model = new ExpressionV2().withType(ExpressionV2Type.BINARY)
+ .withValue("cvkmedrkolpneb")
+ .withOperators(Arrays.asList("fvkskjd", "djxvcxepjfxcmrhi"))
+ .withOperands(Arrays.asList(new ExpressionV2().withType(ExpressionV2Type.BINARY)
+ .withValue("etflirbvqkbxg")
+ .withOperators(Arrays.asList("inyursqf", "rz", "yxmfipvg"))
+ .withOperands(Arrays.asList(new ExpressionV2().withType(ExpressionV2Type.FIELD)
+ .withValue("f")
+ .withOperators(Arrays.asList("xa", "xvftllsu"))
+ .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(), new ExpressionV2()))))));
model = BinaryData.fromObject(model).toObject(ExpressionV2.class);
- Assertions.assertEquals(ExpressionV2Type.UNARY, model.type());
- Assertions.assertEquals("axehiegkpukva", model.value());
- Assertions.assertEquals("lbqhtiijlikio", model.operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.BINARY, model.type());
+ Assertions.assertEquals("cvkmedrkolpneb", model.value());
+ Assertions.assertEquals("fvkskjd", model.operators().get(0));
Assertions.assertEquals(ExpressionV2Type.BINARY, model.operands().get(0).type());
- Assertions.assertEquals("jsmkhk", model.operands().get(0).value());
- Assertions.assertEquals("ccd", model.operands().get(0).operators().get(0));
- Assertions.assertEquals(ExpressionV2Type.BINARY, model.operands().get(0).operands().get(0).type());
- Assertions.assertEquals("ndzvtfkdzqt", model.operands().get(0).operands().get(0).value());
- Assertions.assertEquals("yjqbezv", model.operands().get(0).operands().get(0).operators().get(0));
+ Assertions.assertEquals("etflirbvqkbxg", model.operands().get(0).value());
+ Assertions.assertEquals("inyursqf", model.operands().get(0).operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.FIELD, model.operands().get(0).operands().get(0).type());
+ Assertions.assertEquals("f", model.operands().get(0).operands().get(0).value());
+ Assertions.assertEquals("xa", model.operands().get(0).operands().get(0).operators().get(0));
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoriesDeleteByResourceGroupWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoriesDeleteByResourceGroupWithResponseMockTests.java
index 7e91e16d39cb..cceb883fb550 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoriesDeleteByResourceGroupWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoriesDeleteByResourceGroupWithResponseMockTests.java
@@ -27,7 +27,7 @@ public void testDeleteWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.factories().deleteByResourceGroupWithResponse("csda", "pnhpovrt", com.azure.core.util.Context.NONE);
+ manager.factories().deleteByResourceGroupWithResponse("pnt", "pgwriyxyelzm", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryIdentityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryIdentityTests.java
index 864d347eecbb..eb99f85430f5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryIdentityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryIdentityTests.java
@@ -15,7 +15,7 @@ public final class FactoryIdentityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FactoryIdentity model = BinaryData.fromString(
- "{\"type\":\"SystemAssigned\",\"principalId\":\"25770e8d-ad59-472f-b7fb-3168d7233375\",\"tenantId\":\"b49bdfd1-8d63-4979-acc8-1e9a7d4ec489\",\"userAssignedIdentities\":{\"qjpkcattpngjcrc\":\"dataleyyvx\"}}")
+ "{\"type\":\"SystemAssigned\",\"principalId\":\"2ffd519b-7921-43a8-b545-158a4038b111\",\"tenantId\":\"8fa182c0-3361-4b09-a470-d687353b1a2c\",\"userAssignedIdentities\":{\"qjpkcattpngjcrc\":\"dataleyyvx\"}}")
.toObject(FactoryIdentity.class);
Assertions.assertEquals(FactoryIdentityType.SYSTEM_ASSIGNED, model.type());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryUpdateParametersTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryUpdateParametersTests.java
index 64889efc1a67..29d81cfbfb39 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryUpdateParametersTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FactoryUpdateParametersTests.java
@@ -17,7 +17,7 @@ public final class FactoryUpdateParametersTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FactoryUpdateParameters model = BinaryData.fromString(
- "{\"tags\":{\"bldngkpoc\":\"kouknvudwtiu\",\"npiucgygevqznty\":\"pazyxoegukg\"},\"identity\":{\"type\":\"SystemAssigned\",\"principalId\":\"391bb545-7add-41eb-9096-adaac7584b75\",\"tenantId\":\"6000084f-18a3-4c0c-b65d-eee9126178b4\",\"userAssignedIdentities\":{\"r\":\"datac\",\"dpydn\":\"dataj\",\"sjttgzfbish\":\"datayhxdeoejzicwi\",\"jdeyeamdpha\":\"databkh\"}},\"properties\":{\"publicNetworkAccess\":\"Disabled\"}}")
+ "{\"tags\":{\"bldngkpoc\":\"kouknvudwtiu\",\"npiucgygevqznty\":\"pazyxoegukg\"},\"identity\":{\"type\":\"SystemAssigned\",\"principalId\":\"b08cd623-dce9-4dbd-aa8f-5d12b6dd3164\",\"tenantId\":\"6abb9869-8693-4fa2-a0f8-ca0839cfe7a3\",\"userAssignedIdentities\":{\"r\":\"datac\",\"dpydn\":\"dataj\",\"sjttgzfbish\":\"datayhxdeoejzicwi\",\"jdeyeamdpha\":\"databkh\"}},\"properties\":{\"publicNetworkAccess\":\"Disabled\"}}")
.toObject(FactoryUpdateParameters.class);
Assertions.assertEquals("kouknvudwtiu", model.tags().get("bldngkpoc"));
Assertions.assertEquals(FactoryIdentityType.SYSTEM_ASSIGNED, model.identity().type());
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerReadSettingsTests.java
index da041c6a44e8..454380313218 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerReadSettingsTests.java
@@ -11,24 +11,24 @@ public final class FileServerReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FileServerReadSettings model = BinaryData.fromString(
- "{\"type\":\"FileServerReadSettings\",\"recursive\":\"datatflhe\",\"wildcardFolderPath\":\"dataxefs\",\"wildcardFileName\":\"datamdcoeexwgzsz\",\"fileListPath\":\"datazmqjhghihkhjldw\",\"enablePartitionDiscovery\":\"dataqt\",\"partitionRootPath\":\"datatgn\",\"deleteFilesAfterCompletion\":\"databjvmdkgvu\",\"modifiedDatetimeStart\":\"datamlsuuhwuox\",\"modifiedDatetimeEnd\":\"datai\",\"fileFilter\":\"datazzjo\",\"maxConcurrentConnections\":\"dataygzjrkslqba\",\"disableMetricsCollection\":\"databjxxcruleim\",\"\":{\"gzetuvfpsijpmept\":\"dataoignqumjm\",\"rrvjwbeeolmob\":\"dataqsnpafks\"}}")
+ "{\"type\":\"FileServerReadSettings\",\"recursive\":\"dataiyujn\",\"wildcardFolderPath\":\"datawjxmwalhlj\",\"wildcardFileName\":\"datasnbpiuvqhodfm\",\"fileListPath\":\"datatrsnpbsungnjkkm\",\"enablePartitionDiscovery\":\"datafbjuc\",\"partitionRootPath\":\"datagzjyrdiiwhmrhz\",\"deleteFilesAfterCompletion\":\"datavpjydwmaqeytjp\",\"modifiedDatetimeStart\":\"datadp\",\"modifiedDatetimeEnd\":\"datapdcsvzugiurhgqlv\",\"fileFilter\":\"datajzscrjtnq\",\"maxConcurrentConnections\":\"datapobjufksddxk\",\"disableMetricsCollection\":\"datawxlylxfpvoylf\",\"\":{\"ime\":\"datarguecbthauivg\"}}")
.toObject(FileServerReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FileServerReadSettings model = new FileServerReadSettings().withMaxConcurrentConnections("dataygzjrkslqba")
- .withDisableMetricsCollection("databjxxcruleim")
- .withRecursive("datatflhe")
- .withWildcardFolderPath("dataxefs")
- .withWildcardFileName("datamdcoeexwgzsz")
- .withFileListPath("datazmqjhghihkhjldw")
- .withEnablePartitionDiscovery("dataqt")
- .withPartitionRootPath("datatgn")
- .withDeleteFilesAfterCompletion("databjvmdkgvu")
- .withModifiedDatetimeStart("datamlsuuhwuox")
- .withModifiedDatetimeEnd("datai")
- .withFileFilter("datazzjo");
+ FileServerReadSettings model = new FileServerReadSettings().withMaxConcurrentConnections("datapobjufksddxk")
+ .withDisableMetricsCollection("datawxlylxfpvoylf")
+ .withRecursive("dataiyujn")
+ .withWildcardFolderPath("datawjxmwalhlj")
+ .withWildcardFileName("datasnbpiuvqhodfm")
+ .withFileListPath("datatrsnpbsungnjkkm")
+ .withEnablePartitionDiscovery("datafbjuc")
+ .withPartitionRootPath("datagzjyrdiiwhmrhz")
+ .withDeleteFilesAfterCompletion("datavpjydwmaqeytjp")
+ .withModifiedDatetimeStart("datadp")
+ .withModifiedDatetimeEnd("datapdcsvzugiurhgqlv")
+ .withFileFilter("datajzscrjtnq");
model = BinaryData.fromObject(model).toObject(FileServerReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerWriteSettingsTests.java
index a964613d94d8..9f1117663605 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileServerWriteSettingsTests.java
@@ -13,19 +13,19 @@ public final class FileServerWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FileServerWriteSettings model = BinaryData.fromString(
- "{\"type\":\"FileServerWriteSettings\",\"maxConcurrentConnections\":\"datab\",\"disableMetricsCollection\":\"datavkm\",\"copyBehavior\":\"datajz\",\"metadata\":[{\"name\":\"datavybljqgi\",\"value\":\"dataitz\"},{\"name\":\"datamxcukurkg\",\"value\":\"dataxqanrk\"},{\"name\":\"datadjfsvfbjcnad\",\"value\":\"databrntvhppykrlz\"},{\"name\":\"datalsvxpolatorjm\",\"value\":\"databnmuxlthyxryv\"}],\"\":{\"bffcvtij\":\"datahsigddgbcnqvbn\",\"gvgogczgcm\":\"datalemzrw\",\"rznam\":\"datakmkwddgyqeni\",\"wvgwv\":\"datartcbvifcrnxst\"}}")
+ "{\"type\":\"FileServerWriteSettings\",\"maxConcurrentConnections\":\"dataeegzhhfnaqc\",\"disableMetricsCollection\":\"datapcklowuthfwphn\",\"copyBehavior\":\"datalbljehw\",\"metadata\":[{\"name\":\"dataofneaqahz\",\"value\":\"datanapxhtqwsd\"},{\"name\":\"dataaovubfl\",\"value\":\"datakeub\"},{\"name\":\"dataibuabpvdwhvn\",\"value\":\"databu\"},{\"name\":\"datadkqo\",\"value\":\"dataukvink\"}],\"\":{\"fhdyasklmy\":\"datazqbo\",\"awljatvfddq\":\"datahclxwede\"}}")
.toObject(FileServerWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FileServerWriteSettings model = new FileServerWriteSettings().withMaxConcurrentConnections("datab")
- .withDisableMetricsCollection("datavkm")
- .withCopyBehavior("datajz")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datavybljqgi").withValue("dataitz"),
- new MetadataItem().withName("datamxcukurkg").withValue("dataxqanrk"),
- new MetadataItem().withName("datadjfsvfbjcnad").withValue("databrntvhppykrlz"),
- new MetadataItem().withName("datalsvxpolatorjm").withValue("databnmuxlthyxryv")));
+ FileServerWriteSettings model = new FileServerWriteSettings().withMaxConcurrentConnections("dataeegzhhfnaqc")
+ .withDisableMetricsCollection("datapcklowuthfwphn")
+ .withCopyBehavior("datalbljehw")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("dataofneaqahz").withValue("datanapxhtqwsd"),
+ new MetadataItem().withName("dataaovubfl").withValue("datakeub"),
+ new MetadataItem().withName("dataibuabpvdwhvn").withValue("databu"),
+ new MetadataItem().withName("datadkqo").withValue("dataukvink")));
model = BinaryData.fromObject(model).toObject(FileServerWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTests.java
index c7388a61013c..9c2adb494279 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTests.java
@@ -21,44 +21,48 @@ public final class FileShareDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FileShareDataset model = BinaryData.fromString(
- "{\"type\":\"FileShare\",\"typeProperties\":{\"folderPath\":\"datalmcvrjaznotdofq\",\"fileName\":\"databq\",\"modifiedDatetimeStart\":\"dataqkpsbqsb\",\"modifiedDatetimeEnd\":\"dataitaftazgcxsvqlc\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"dataylamxow\",\"deserializer\":\"datacjoyutehlkarvt\",\"\":{\"whpcekggvmfnn\":\"datauksxiknsgofun\",\"txtpwcvgifws\":\"databxngdfkkede\"}},\"fileFilter\":\"datajzijaciwmmpdt\",\"compression\":{\"type\":\"dataonbz\",\"level\":\"datanfzyviiwsuanz\",\"\":{\"kzqqhbtfloilmkf\":\"datayui\",\"ikdlpsxntugfwimq\":\"dataeoiipjpngvyvu\",\"fmvswx\":\"dataryclo\",\"wulkr\":\"datajeleifqhdxt\"}}},\"description\":\"paevykbyjecrqk\",\"structure\":\"datakkchsfoulborc\",\"schema\":\"dataibsdqbdyblpe\",\"linkedServiceName\":{\"referenceName\":\"t\",\"parameters\":{\"lerufollcshju\":\"datapgweoqhbjqlqf\",\"xvjeazrah\":\"dataihbymjjvtpne\",\"qamcthtpqgfz\":\"datalhbimyii\"}},\"parameters\":{\"vflgzhc\":{\"type\":\"Bool\",\"defaultValue\":\"datakdi\"},\"pccxziv\":{\"type\":\"Object\",\"defaultValue\":\"datawahcrxofgrutv\"},\"jd\":{\"type\":\"SecureString\",\"defaultValue\":\"datahzghhhkvn\"}},\"annotations\":[\"dataq\"],\"folder\":{\"name\":\"njvpmxn\"},\"\":{\"olrwvtlgxyfj\":\"datazstqlf\"}}")
+ "{\"type\":\"FileShare\",\"typeProperties\":{\"folderPath\":\"dataeyobqaj\",\"fileName\":\"datairv\",\"modifiedDatetimeStart\":\"datarvkgpogplbjuvl\",\"modifiedDatetimeEnd\":\"dataxnrnjh\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"dataegesbxne\",\"deserializer\":\"datamjmoplu\",\"\":{\"mwqpdkesjqbzkqm\":\"datakkfhsovadkrmj\",\"tspzjnrr\":\"datavporiwbwggi\",\"htrgz\":\"dataikwsbzrhdugq\",\"jfhrjhiycbause\":\"dataru\"}},\"fileFilter\":\"dataczkvihvtuw\",\"compression\":{\"type\":\"datasqwzszoszjgzu\",\"level\":\"datafnyskwwu\",\"\":{\"slhip\":\"dataczavoj\",\"vchyluqalpcufj\":\"dataukvbljpxpr\",\"tiztqds\":\"dataf\"}}},\"description\":\"h\",\"structure\":\"datasaaxxsrit\",\"schema\":\"datawbaaes\",\"linkedServiceName\":{\"referenceName\":\"yefmxwoqotii\",\"parameters\":{\"sty\":\"datapasrvrmt\",\"k\":\"datakjhorlxkpy\",\"b\":\"datannycntrqxxwtd\",\"oxtdyqavfx\":\"datajtsuhqh\"}},\"parameters\":{\"bgh\":{\"type\":\"SecureString\",\"defaultValue\":\"datasyaksinpaamih\"},\"iys\":{\"type\":\"Array\",\"defaultValue\":\"datagpbgchcgsfzhbj\"},\"sgw\":{\"type\":\"SecureString\",\"defaultValue\":\"datasdjpgxe\"},\"f\":{\"type\":\"Int\",\"defaultValue\":\"dataferznzcbivoveomk\"}},\"annotations\":[\"dataooplfpohim\",\"datackycjpeebzn\"],\"folder\":{\"name\":\"xsuloutnpb\"},\"\":{\"cdmwk\":\"dataoqohgp\",\"sl\":\"dataupf\"}}")
.toObject(FileShareDataset.class);
- Assertions.assertEquals("paevykbyjecrqk", model.description());
- Assertions.assertEquals("t", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("vflgzhc").type());
- Assertions.assertEquals("njvpmxn", model.folder().name());
+ Assertions.assertEquals("h", model.description());
+ Assertions.assertEquals("yefmxwoqotii", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("bgh").type());
+ Assertions.assertEquals("xsuloutnpb", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FileShareDataset model = new FileShareDataset().withDescription("paevykbyjecrqk")
- .withStructure("datakkchsfoulborc")
- .withSchema("dataibsdqbdyblpe")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("t")
- .withParameters(mapOf("lerufollcshju", "datapgweoqhbjqlqf", "xvjeazrah", "dataihbymjjvtpne",
- "qamcthtpqgfz", "datalhbimyii")))
- .withParameters(mapOf("vflgzhc",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datakdi"), "pccxziv",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datawahcrxofgrutv"), "jd",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datahzghhhkvn")))
- .withAnnotations(Arrays.asList("dataq"))
- .withFolder(new DatasetFolder().withName("njvpmxn"))
- .withFolderPath("datalmcvrjaznotdofq")
- .withFileName("databq")
- .withModifiedDatetimeStart("dataqkpsbqsb")
- .withModifiedDatetimeEnd("dataitaftazgcxsvqlc")
- .withFormat(new DatasetStorageFormat().withSerializer("dataylamxow")
- .withDeserializer("datacjoyutehlkarvt")
+ FileShareDataset model = new FileShareDataset().withDescription("h")
+ .withStructure("datasaaxxsrit")
+ .withSchema("datawbaaes")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("yefmxwoqotii")
+ .withParameters(mapOf("sty", "datapasrvrmt", "k", "datakjhorlxkpy", "b", "datannycntrqxxwtd",
+ "oxtdyqavfx", "datajtsuhqh")))
+ .withParameters(mapOf("bgh",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datasyaksinpaamih"),
+ "iys",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datagpbgchcgsfzhbj"),
+ "sgw",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datasdjpgxe"), "f",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataferznzcbivoveomk")))
+ .withAnnotations(Arrays.asList("dataooplfpohim", "datackycjpeebzn"))
+ .withFolder(new DatasetFolder().withName("xsuloutnpb"))
+ .withFolderPath("dataeyobqaj")
+ .withFileName("datairv")
+ .withModifiedDatetimeStart("datarvkgpogplbjuvl")
+ .withModifiedDatetimeEnd("dataxnrnjh")
+ .withFormat(new DatasetStorageFormat().withSerializer("dataegesbxne")
+ .withDeserializer("datamjmoplu")
.withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withFileFilter("datajzijaciwmmpdt")
- .withCompression(new DatasetCompression().withType("dataonbz")
- .withLevel("datanfzyviiwsuanz")
+ .withFileFilter("dataczkvihvtuw")
+ .withCompression(new DatasetCompression().withType("datasqwzszoszjgzu")
+ .withLevel("datafnyskwwu")
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(FileShareDataset.class);
- Assertions.assertEquals("paevykbyjecrqk", model.description());
- Assertions.assertEquals("t", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("vflgzhc").type());
- Assertions.assertEquals("njvpmxn", model.folder().name());
+ Assertions.assertEquals("h", model.description());
+ Assertions.assertEquals("yefmxwoqotii", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("bgh").type());
+ Assertions.assertEquals("xsuloutnpb", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTypePropertiesTests.java
index 482d63d44938..d340ff6ea065 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileShareDatasetTypePropertiesTests.java
@@ -15,23 +15,22 @@ public final class FileShareDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FileShareDatasetTypeProperties model = BinaryData.fromString(
- "{\"folderPath\":\"dataequ\",\"fileName\":\"datazyyopoaytwwgwqub\",\"modifiedDatetimeStart\":\"databvufrkwjiemimdtn\",\"modifiedDatetimeEnd\":\"datawew\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datareeedddrftfquul\",\"deserializer\":\"datalhs\",\"\":{\"b\":\"dataeeu\",\"e\":\"datanqyxfedq\",\"nxoqgv\":\"datadqw\"}},\"fileFilter\":\"datapgg\",\"compression\":{\"type\":\"datameyobqajejirvavr\",\"level\":\"datagpogpl\",\"\":{\"rnjhinaeges\":\"datavlnhx\",\"pl\":\"dataxnepqmjm\",\"ovadkrmjx\":\"datakfykkfh\",\"jqbzkqmxv\":\"datawqpdke\"}}}")
+ "{\"folderPath\":\"datadzauiunyev\",\"fileName\":\"datazdsytciks\",\"modifiedDatetimeStart\":\"datacamwuynfxkcgs\",\"modifiedDatetimeEnd\":\"datamvhadrpbatvy\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datajqkqws\",\"deserializer\":\"datatvjkowggxawwdm\",\"\":{\"g\":\"datankteiidlbovwbclp\",\"kjcnerek\":\"datagani\",\"gpwxtvce\":\"datajulskwwnqhql\",\"vxwve\":\"dataavv\"}},\"fileFilter\":\"datanlrjcsmwevguyfln\",\"compression\":{\"type\":\"datalr\",\"level\":\"datafzcde\",\"\":{\"csfqbirtybce\":\"datawezhyfkdilbwqlq\",\"dvuelumodpegqxso\":\"datafjnxodnjyhzfaxs\",\"hlbeqvhs\":\"datachazrqoxz\"}}}")
.toObject(FileShareDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FileShareDatasetTypeProperties model = new FileShareDatasetTypeProperties().withFolderPath("dataequ")
- .withFileName("datazyyopoaytwwgwqub")
- .withModifiedDatetimeStart("databvufrkwjiemimdtn")
- .withModifiedDatetimeEnd("datawew")
- .withFormat(new DatasetStorageFormat().withSerializer("datareeedddrftfquul")
- .withDeserializer("datalhs")
+ FileShareDatasetTypeProperties model = new FileShareDatasetTypeProperties().withFolderPath("datadzauiunyev")
+ .withFileName("datazdsytciks")
+ .withModifiedDatetimeStart("datacamwuynfxkcgs")
+ .withModifiedDatetimeEnd("datamvhadrpbatvy")
+ .withFormat(new DatasetStorageFormat().withSerializer("datajqkqws")
+ .withDeserializer("datatvjkowggxawwdm")
.withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withFileFilter("datapgg")
- .withCompression(new DatasetCompression().withType("datameyobqajejirvavr")
- .withLevel("datagpogpl")
- .withAdditionalProperties(mapOf()));
+ .withFileFilter("datanlrjcsmwevguyfln")
+ .withCompression(
+ new DatasetCompression().withType("datalr").withLevel("datafzcde").withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(FileShareDatasetTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSinkTests.java
index 04105dda237e..c5adf2313178 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSinkTests.java
@@ -11,19 +11,19 @@ public final class FileSystemSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FileSystemSink model = BinaryData.fromString(
- "{\"type\":\"FileSystemSink\",\"copyBehavior\":\"datalvdenhguvaimko\",\"writeBatchSize\":\"datappsnljduwkb\",\"writeBatchTimeout\":\"datalmrhn\",\"sinkRetryCount\":\"datavlvdjxbjqiab\",\"sinkRetryWait\":\"dataevvowiypyljzkx\",\"maxConcurrentConnections\":\"datafyv\",\"disableMetricsCollection\":\"dataftaq\",\"\":{\"xewemtazmrejz\":\"datarjlhmney\"}}")
+ "{\"type\":\"FileSystemSink\",\"copyBehavior\":\"dataapgqx\",\"writeBatchSize\":\"databvwxyumqoqw\",\"writeBatchTimeout\":\"datab\",\"sinkRetryCount\":\"datayeigngrzvegxmx\",\"sinkRetryWait\":\"datahqxzewlwwdmp\",\"maxConcurrentConnections\":\"datacpccovzkwhdtf\",\"disableMetricsCollection\":\"datafctsfujdap\",\"\":{\"atexkwcolnae\":\"dataamgbnktgotddyd\",\"d\":\"datawsdyvahn\",\"mekgtkojrr\":\"datacpmvnzhdsa\"}}")
.toObject(FileSystemSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FileSystemSink model = new FileSystemSink().withWriteBatchSize("datappsnljduwkb")
- .withWriteBatchTimeout("datalmrhn")
- .withSinkRetryCount("datavlvdjxbjqiab")
- .withSinkRetryWait("dataevvowiypyljzkx")
- .withMaxConcurrentConnections("datafyv")
- .withDisableMetricsCollection("dataftaq")
- .withCopyBehavior("datalvdenhguvaimko");
+ FileSystemSink model = new FileSystemSink().withWriteBatchSize("databvwxyumqoqw")
+ .withWriteBatchTimeout("datab")
+ .withSinkRetryCount("datayeigngrzvegxmx")
+ .withSinkRetryWait("datahqxzewlwwdmp")
+ .withMaxConcurrentConnections("datacpccovzkwhdtf")
+ .withDisableMetricsCollection("datafctsfujdap")
+ .withCopyBehavior("dataapgqx");
model = BinaryData.fromObject(model).toObject(FileSystemSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSourceTests.java
index 49cafc327019..b1d5df3e4708 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FileSystemSourceTests.java
@@ -11,18 +11,18 @@ public final class FileSystemSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FileSystemSource model = BinaryData.fromString(
- "{\"type\":\"FileSystemSource\",\"recursive\":\"dataskzw\",\"additionalColumns\":\"datah\",\"sourceRetryCount\":\"datahz\",\"sourceRetryWait\":\"datac\",\"maxConcurrentConnections\":\"datasoxoavlwwpv\",\"disableMetricsCollection\":\"datanjwvc\",\"\":{\"wmwkdehjloz\":\"dataqlceflgsndurhqoz\",\"uxedpqwz\":\"datacwo\",\"rubcvucvebdfm\":\"datazimgbxjgxrha\",\"eealphuclkbwk\":\"datajn\"}}")
+ "{\"type\":\"FileSystemSource\",\"recursive\":\"datamihgksqwzuosyyx\",\"additionalColumns\":\"datadxzudfar\",\"sourceRetryCount\":\"datayrdy\",\"sourceRetryWait\":\"datawgikpdpudqiwhvx\",\"maxConcurrentConnections\":\"datavpoeuufw\",\"disableMetricsCollection\":\"datadeffrbxzjedy\",\"\":{\"lnomqbdvjl\":\"datasxspnmfydphl\",\"lbpehvjpgllrhnlx\":\"dataf\",\"dchdsxvkmgppxz\":\"datatpgzybezmyjq\"}}")
.toObject(FileSystemSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FileSystemSource model = new FileSystemSource().withSourceRetryCount("datahz")
- .withSourceRetryWait("datac")
- .withMaxConcurrentConnections("datasoxoavlwwpv")
- .withDisableMetricsCollection("datanjwvc")
- .withRecursive("dataskzw")
- .withAdditionalColumns("datah");
+ FileSystemSource model = new FileSystemSource().withSourceRetryCount("datayrdy")
+ .withSourceRetryWait("datawgikpdpudqiwhvx")
+ .withMaxConcurrentConnections("datavpoeuufw")
+ .withDisableMetricsCollection("datadeffrbxzjedy")
+ .withRecursive("datamihgksqwzuosyyx")
+ .withAdditionalColumns("datadxzudfar");
model = BinaryData.fromObject(model).toObject(FileSystemSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTests.java
index fd6999e72b73..035886df0cfd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTests.java
@@ -21,52 +21,54 @@ public final class FilterActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FilterActivity model = BinaryData.fromString(
- "{\"type\":\"Filter\",\"typeProperties\":{\"items\":{\"value\":\"ehtrgybfumoro\"},\"condition\":{\"value\":\"rutbfkynwwm\"}},\"name\":\"zpyrzazkal\",\"description\":\"vmknwlbz\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"ntgsju\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"iuaaqgkvkoynjuc\":\"dataphwgixypgvwmvafh\"}},{\"activity\":\"yjblafvvndkvbcrq\",\"dependencyConditions\":[\"Skipped\",\"Skipped\"],\"\":{\"hgbf\":\"datagjneohxkisz\"}},{\"activity\":\"jodskqyjsdxgefk\",\"dependencyConditions\":[\"Failed\"],\"\":{\"agpjociu\":\"dataetorrchfuwfr\",\"djkwyzqnl\":\"datandgp\",\"kaciq\":\"datazymiv\"}}],\"userProperties\":[{\"name\":\"f\",\"value\":\"dataksywdtgz\"},{\"name\":\"gqfl\",\"value\":\"datauxyakof\"},{\"name\":\"soe\",\"value\":\"datahqtt\"},{\"name\":\"qcpcloo\",\"value\":\"datace\"}],\"\":{\"orn\":\"datasmnyfahidlscdow\",\"pirgdsqcbxkw\":\"datayjqzjtdkojbxkodc\"}}")
+ "{\"type\":\"Filter\",\"typeProperties\":{\"items\":{\"value\":\"ckhqooqniqv\"},\"condition\":{\"value\":\"qsudtmkmgc\"}},\"name\":\"pv\",\"description\":\"ngvpsuk\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"gf\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Succeeded\",\"Skipped\"],\"\":{\"tjtiidozfrgvqurr\":\"dataekoxylcbp\",\"vohjg\":\"datanijdr\",\"lzsgpoiccbzqko\":\"dataoiikr\"}},{\"activity\":\"ja\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"ttpvtwgbf\":\"datakqnlzytazqsu\"}},{\"activity\":\"osdizpgcq\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Skipped\"],\"\":{\"lhetgwv\":\"datap\",\"oqhamr\":\"dataenmue\",\"oixiduzrdvhgyj\":\"datatrny\"}},{\"activity\":\"mbj\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Succeeded\"],\"\":{\"zzym\":\"datalrungsolxlxl\",\"iudelm\":\"datazz\",\"yxaj\":\"databx\"}}],\"userProperties\":[{\"name\":\"cgxwa\",\"value\":\"datauudnygtsjafvzd\"}],\"\":{\"vbnmzjwh\":\"datahuzybmsyzz\"}}")
.toObject(FilterActivity.class);
- Assertions.assertEquals("zpyrzazkal", model.name());
- Assertions.assertEquals("vmknwlbz", model.description());
+ Assertions.assertEquals("pv", model.name());
+ Assertions.assertEquals("ngvpsuk", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("ntgsju", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("f", model.userProperties().get(0).name());
- Assertions.assertEquals("ehtrgybfumoro", model.items().value());
- Assertions.assertEquals("rutbfkynwwm", model.condition().value());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("gf", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("cgxwa", model.userProperties().get(0).name());
+ Assertions.assertEquals("ckhqooqniqv", model.items().value());
+ Assertions.assertEquals("qsudtmkmgc", model.condition().value());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FilterActivity model = new FilterActivity().withName("zpyrzazkal")
- .withDescription("vmknwlbz")
+ FilterActivity model = new FilterActivity().withName("pv")
+ .withDescription("ngvpsuk")
.withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ntgsju")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("gf")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("yjblafvvndkvbcrq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
+ new ActivityDependency().withActivity("ja")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("jodskqyjsdxgefk")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("osdizpgcq")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED,
+ DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("mbj")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED,
+ DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("f").withValue("dataksywdtgz"),
- new UserProperty().withName("gqfl").withValue("datauxyakof"),
- new UserProperty().withName("soe").withValue("datahqtt"),
- new UserProperty().withName("qcpcloo").withValue("datace")))
- .withItems(new Expression().withValue("ehtrgybfumoro"))
- .withCondition(new Expression().withValue("rutbfkynwwm"));
+ .withUserProperties(Arrays.asList(new UserProperty().withName("cgxwa").withValue("datauudnygtsjafvzd")))
+ .withItems(new Expression().withValue("ckhqooqniqv"))
+ .withCondition(new Expression().withValue("qsudtmkmgc"));
model = BinaryData.fromObject(model).toObject(FilterActivity.class);
- Assertions.assertEquals("zpyrzazkal", model.name());
- Assertions.assertEquals("vmknwlbz", model.description());
+ Assertions.assertEquals("pv", model.name());
+ Assertions.assertEquals("ngvpsuk", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("ntgsju", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("f", model.userProperties().get(0).name());
- Assertions.assertEquals("ehtrgybfumoro", model.items().value());
- Assertions.assertEquals("rutbfkynwwm", model.condition().value());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("gf", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("cgxwa", model.userProperties().get(0).name());
+ Assertions.assertEquals("ckhqooqniqv", model.items().value());
+ Assertions.assertEquals("qsudtmkmgc", model.condition().value());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTypePropertiesTests.java
index 4a0790cc369f..57d38acd8eb0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FilterActivityTypePropertiesTests.java
@@ -13,19 +13,19 @@ public final class FilterActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FilterActivityTypeProperties model
- = BinaryData.fromString("{\"items\":{\"value\":\"nqsybwjvifgjztzh\"},\"condition\":{\"value\":\"hyqj\"}}")
+ = BinaryData.fromString("{\"items\":{\"value\":\"bsgzewyfh\"},\"condition\":{\"value\":\"z\"}}")
.toObject(FilterActivityTypeProperties.class);
- Assertions.assertEquals("nqsybwjvifgjztzh", model.items().value());
- Assertions.assertEquals("hyqj", model.condition().value());
+ Assertions.assertEquals("bsgzewyfh", model.items().value());
+ Assertions.assertEquals("z", model.condition().value());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
FilterActivityTypeProperties model
- = new FilterActivityTypeProperties().withItems(new Expression().withValue("nqsybwjvifgjztzh"))
- .withCondition(new Expression().withValue("hyqj"));
+ = new FilterActivityTypeProperties().withItems(new Expression().withValue("bsgzewyfh"))
+ .withCondition(new Expression().withValue("z"));
model = BinaryData.fromObject(model).toObject(FilterActivityTypeProperties.class);
- Assertions.assertEquals("nqsybwjvifgjztzh", model.items().value());
- Assertions.assertEquals("hyqj", model.condition().value());
+ Assertions.assertEquals("bsgzewyfh", model.items().value());
+ Assertions.assertEquals("z", model.condition().value());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTests.java
index 6cdfc9e5df52..03018866450d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTests.java
@@ -22,148 +22,163 @@ public final class ForEachActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ForEachActivity model = BinaryData.fromString(
- "{\"type\":\"ForEach\",\"typeProperties\":{\"isSequential\":true,\"batchCount\":1022539711,\"items\":{\"value\":\"wdu\"},\"activities\":[{\"type\":\"Activity\",\"name\":\"krskqgokhpzvph\",\"description\":\"f\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"kdhopzymhrfwchi\",\"dependencyConditions\":[\"Failed\",\"Succeeded\",\"Completed\"],\"\":{\"qhlbsvyo\":\"dataezkwdexldo\"}},{\"activity\":\"iexmfeechltxa\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Succeeded\",\"Completed\"],\"\":{\"bmeksegdjq\":\"datafeouucgzifo\"}},{\"activity\":\"oc\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Succeeded\",\"Skipped\"],\"\":{\"zcwjaqyvnol\":\"dataimenjhtwkn\",\"m\":\"datapz\",\"quiqkuxajl\":\"databss\"}}],\"userProperties\":[{\"name\":\"fzpkrnowexfykdi\",\"value\":\"datacwbnmaiqdjoir\"}],\"\":{\"smdsmzkjlhkco\":\"datammvjrxoidm\",\"yfiochfx\":\"dataxrs\",\"ybjynzo\":\"datae\",\"fmhypwglkvspbd\":\"dataeudhvszwgmpzbx\"}},{\"type\":\"Activity\",\"name\":\"ushzfnlqnr\",\"description\":\"mrvpswe\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"dhszkudl\",\"dependencyConditions\":[\"Failed\",\"Succeeded\",\"Completed\",\"Skipped\"],\"\":{\"fxnokpkgrub\":\"datavdabgctmfntl\",\"hdkx\":\"datazgz\",\"rhgelsvo\":\"datahlinjerkdurch\",\"rqhqqkhzpwsa\":\"datavqjthluo\"}},{\"activity\":\"wsentrcdz\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Completed\",\"Failed\"],\"\":{\"rbbgl\":\"datamduwpqvdduvx\"}},{\"activity\":\"wfbgkyonadtywzrn\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Completed\"],\"\":{\"cfprioabqxwid\":\"dataptxmdadfygj\"}},{\"activity\":\"xeonnolrsmxt\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Succeeded\"],\"\":{\"uotexlpqydgfzet\":\"dataaxmo\"}}],\"userProperties\":[{\"name\":\"mnseigoalxwuq\",\"value\":\"dataczrskdovgkpq\"},{\"name\":\"zrxhghsmlxogim\",\"value\":\"datahxyx\"},{\"name\":\"lxawixdcy\",\"value\":\"datadqamiy\"}],\"\":{\"zco\":\"datazlbcamdzoauvwjkg\",\"aqxztywzaq\":\"datawcnnzacqludq\",\"zlzpowsefpg\":\"datafqtstmyfebb\",\"pzbsytwt\":\"dataw\"}},{\"type\":\"Activity\",\"name\":\"vcdtsvgyzmafq\",\"description\":\"wupuubyvwejy\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"hrxoekyf\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"jxjaaocjlwco\":\"datapdgnsmhrpzbyudko\",\"vmzxrhve\":\"datawcrextdymkzbliu\",\"guvqghuehgcqhlfq\":\"datangzjxjbklta\",\"r\":\"datamjldeluqqnf\"}}],\"userProperties\":[{\"name\":\"luomaltvvp\",\"value\":\"datadhtdapkdahyn\"},{\"name\":\"tixrkjogyqrmt\",\"value\":\"dataiclsxuibyfylhf\"}],\"\":{\"cwuz\":\"dataauqylmlunquvlva\",\"gynqedn\":\"datalx\",\"qcxzdlfs\":\"dataidacskul\"}},{\"type\":\"Activity\",\"name\":\"ubjv\",\"description\":\"rcrknnruceuwfmrc\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"bzhto\",\"dependencyConditions\":[\"Failed\"],\"\":{\"d\":\"dataothewokprvpkd\",\"pcghcf\":\"datadsmavtndgfmtxim\"}}],\"userProperties\":[{\"name\":\"qefdtpurgerybdi\",\"value\":\"datajeea\"},{\"name\":\"werukuoeyyxcd\",\"value\":\"datalkkglahdwxyite\"},{\"name\":\"foek\",\"value\":\"dataxhjvtfzaqnoqgfyo\"},{\"name\":\"ohux\",\"value\":\"datafxkjrhgwgsba\"}],\"\":{\"ifsguolfku\":\"datakqvku\"}}]},\"name\":\"mwezsirhpigq\",\"description\":\"wdrcjyywbssli\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"bzxidqqesln\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Succeeded\",\"Completed\"],\"\":{\"yxamyjh\":\"datarlzzztgzf\",\"sjblqmddtpwil\":\"datarzu\"}},{\"activity\":\"gjoboqt\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\"],\"\":{\"fmtm\":\"datawgcuv\",\"gtskolbjylostrc\":\"datapvoazgtlxgtusw\"}},{\"activity\":\"qocerb\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Succeeded\"],\"\":{\"ean\":\"datazigelphauldals\"}},{\"activity\":\"esw\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Completed\",\"Completed\"],\"\":{\"cjulunbtufic\":\"datafprskxhghvgvi\",\"oabma\":\"datapibnjpivoizxk\",\"licivod\":\"datajlahd\",\"bmjheyntsdwxpa\":\"datada\"}}],\"userProperties\":[{\"name\":\"grjkgko\",\"value\":\"datauedm\"},{\"name\":\"ocrkfygjywpkb\",\"value\":\"datavjyenwvgvhhou\"}],\"\":{\"oii\":\"dataihwlkflj\"}}")
+ "{\"type\":\"ForEach\",\"typeProperties\":{\"isSequential\":true,\"batchCount\":797541414,\"items\":{\"value\":\"sgrcrknnr\"},\"activities\":[{\"type\":\"Activity\",\"name\":\"euwfmrckatnjik\",\"description\":\"htovsyi\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"kprv\",\"dependencyConditions\":[\"Failed\"],\"\":{\"mavtndgfmtximnpc\":\"datasd\"}},{\"activity\":\"hcfu\",\"dependencyConditions\":[\"Completed\",\"Skipped\",\"Skipped\",\"Succeeded\"],\"\":{\"diajeeahweru\":\"dataurgery\",\"lahdwxyitezf\":\"datauoeyyxcdwlkk\"}},{\"activity\":\"ekaxh\",\"dependencyConditions\":[\"Failed\",\"Succeeded\",\"Completed\",\"Failed\"],\"\":{\"y\":\"dataoqg\",\"s\":\"datafohuxpfxkjrhgw\",\"uzifsguolfkup\":\"dataaewkkqv\"}}],\"userProperties\":[{\"name\":\"zsirhp\",\"value\":\"datagqdz\"},{\"name\":\"drcj\",\"value\":\"dataywbssli\"},{\"name\":\"hcpuddbzxi\",\"value\":\"dataqqeslnaoxke\"},{\"name\":\"utrlzzztg\",\"value\":\"datafzyxamyjhp\"}],\"\":{\"lqmddtpwilyg\":\"datavsj\",\"oqtscduuywg\":\"datao\"}},{\"type\":\"Activity\",\"name\":\"uvcfmtmmpvoa\",\"description\":\"tlx\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"t\",\"dependencyConditions\":[\"Failed\",\"Succeeded\"],\"\":{\"erbwa\":\"dataylostrcbqo\",\"elphauldalspe\":\"dataqsubzi\",\"llqyvblfprskxhg\":\"datanhesw\",\"tuficip\":\"datavgviycjulun\"}},{\"activity\":\"bnjpivoizxkh\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Completed\",\"Skipped\"],\"\":{\"bmjheyntsdwxpa\":\"dataahdplicivoduda\",\"crkf\":\"dataubgrjkgkoxuedml\",\"bvvjyenwvgvhhouh\":\"datagjywp\"}},{\"activity\":\"tih\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"mjoycyvxbrthw\":\"datajooiiviwl\",\"uoghvkzmgvtem\":\"dataitrwwkofoqrvnh\",\"hwypdhrq\":\"datayfj\"}},{\"activity\":\"jlsatoxsga\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"ftlbtotu\":\"dataxmxgqgquulyrtk\",\"cwrykwmvcxyu\":\"datazasrwoxumnucqew\"}}],\"userProperties\":[{\"name\":\"idcytnzy\",\"value\":\"datasydwgq\"},{\"name\":\"srlhxfmvngdrnt\",\"value\":\"datavn\"}],\"\":{\"rcojwiigtdj\":\"datahnbwdborjy\",\"iftm\":\"dataczoqpkpib\",\"hlnaymsgbyho\":\"datazofont\",\"ennobjixoqqjbsag\":\"dataqugycorgnxmn\"}},{\"type\":\"Activity\",\"name\":\"lpuqfmrimwlpa\",\"description\":\"wxuiakt\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"hwysieoe\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"ylsuiyvbildwqlx\":\"datarhpgavropkoezcab\",\"qei\":\"datav\",\"axswiind\":\"datapylpmtwdvdtzdr\",\"hacvsj\":\"dataurwzrx\"}},{\"activity\":\"mbtvcdsl\",\"dependencyConditions\":[\"Completed\"],\"\":{\"kzkaoonbziklqyzr\":\"datanxhszrotunnkb\",\"zvvkehasxjmf\":\"dataawjk\",\"qxwcimamtqfrdfo\":\"databs\"}},{\"activity\":\"qfvczuuanrjcrpx\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Succeeded\",\"Succeeded\"],\"\":{\"kmlfcgk\":\"dataroxvsclmt\"}}],\"userProperties\":[{\"name\":\"tp\",\"value\":\"datazuaznsbvubbe\"},{\"name\":\"tyymljotimpuwgrn\",\"value\":\"dataxrizse\"}],\"\":{\"dcfwawzj\":\"datadran\",\"hic\":\"datafauubcvnafx\",\"grufbzgnrjfzba\":\"datacmviclhommhaxt\"}},{\"type\":\"Activity\",\"name\":\"qmmkmqdfjeu\",\"description\":\"qstczpsk\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"uqvywolc\",\"dependencyConditions\":[\"Failed\"],\"\":{\"osaxg\":\"datakheh\",\"hhhexgxnmfo\":\"datamspnzq\",\"tycfostzdxb\":\"dataxiyzvfo\"}},{\"activity\":\"pglcbhahxsjxurrh\",\"dependencyConditions\":[\"Failed\",\"Succeeded\"],\"\":{\"mz\":\"datajzifyhujgrb\",\"scrfbdttcfwjzquw\":\"datagxjoimozsef\"}}],\"userProperties\":[{\"name\":\"ihlolau\",\"value\":\"datar\"}],\"\":{\"yajijzrt\":\"datafefxvggkjbhsnyy\",\"ki\":\"datafngonhmblkkelz\",\"h\":\"datamne\",\"qvcfzr\":\"dataynencaf\"}}]},\"name\":\"wxgczwxyghsppm\",\"description\":\"c\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"chygbeofiwbtfkiu\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"fkukaa\":\"datasxjrafh\",\"gqhefeasm\":\"datawnqijphhuvflg\",\"pcxxpyrtajlyde\":\"datadguodoujpwqbotlv\"}},{\"activity\":\"qfvrqru\",\"dependencyConditions\":[\"Failed\"],\"\":{\"jzvceyxvfoyuyk\":\"datauxbqdwbjh\"}},{\"activity\":\"dggyhpuhcc\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Skipped\"],\"\":{\"abdkbkblop\":\"datatpt\",\"zsfvri\":\"datamorfzuhvycdndcz\",\"pqcqinvkm\":\"datakplnd\",\"qabvwbgsanv\":\"databtpbwthz\"}}],\"userProperties\":[{\"name\":\"mbxshrae\",\"value\":\"dataclhzmegqtzhr\"},{\"name\":\"eibku\",\"value\":\"dataolu\"}],\"\":{\"keuraylygclwbu\":\"dataeqdmolmcyba\",\"fnhzgtydllauno\":\"dataqamvdnexqvt\",\"pglgkeaz\":\"datalkny\"}}")
.toObject(ForEachActivity.class);
- Assertions.assertEquals("mwezsirhpigq", model.name());
- Assertions.assertEquals("wdrcjyywbssli", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("bzxidqqesln", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("grjkgko", model.userProperties().get(0).name());
+ Assertions.assertEquals("wxgczwxyghsppm", model.name());
+ Assertions.assertEquals("c", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("chygbeofiwbtfkiu", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("mbxshrae", model.userProperties().get(0).name());
Assertions.assertEquals(true, model.isSequential());
- Assertions.assertEquals(1022539711, model.batchCount());
- Assertions.assertEquals("wdu", model.items().value());
- Assertions.assertEquals("krskqgokhpzvph", model.activities().get(0).name());
- Assertions.assertEquals("f", model.activities().get(0).description());
+ Assertions.assertEquals(797541414, model.batchCount());
+ Assertions.assertEquals("sgrcrknnr", model.items().value());
+ Assertions.assertEquals("euwfmrckatnjik", model.activities().get(0).name());
+ Assertions.assertEquals("htovsyi", model.activities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("kdhopzymhrfwchi", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("kprv", model.activities().get(0).dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.FAILED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("fzpkrnowexfykdi", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("zsirhp", model.activities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ForEachActivity model = new ForEachActivity().withName("mwezsirhpigq")
- .withDescription("wdrcjyywbssli")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("bzxidqqesln")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("gjoboqt")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("qocerb")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
- DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("esw")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
- DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("grjkgko").withValue("datauedm"),
- new UserProperty().withName("ocrkfygjywpkb").withValue("datavjyenwvgvhhou")))
- .withIsSequential(true)
- .withBatchCount(1022539711)
- .withItems(new Expression().withValue("wdu"))
- .withActivities(Arrays.asList(
- new Activity().withName("krskqgokhpzvph")
- .withDescription("f")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("kdhopzymhrfwchi")
- .withDependencyConditions(Arrays.asList(
- DependencyCondition.FAILED, DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("iexmfeechltxa")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("oc")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("fzpkrnowexfykdi").withValue("datacwbnmaiqdjoir")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("ushzfnlqnr")
- .withDescription("mrvpswe")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("dhszkudl")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wsentrcdz")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED,
- DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wfbgkyonadtywzrn")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("xeonnolrsmxt")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("mnseigoalxwuq").withValue("dataczrskdovgkpq"),
- new UserProperty().withName("zrxhghsmlxogim").withValue("datahxyx"),
- new UserProperty().withName("lxawixdcy").withValue("datadqamiy")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("vcdtsvgyzmafq")
- .withDescription("wupuubyvwejy")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("hrxoekyf")
+ ForEachActivity model
+ = new ForEachActivity().withName("wxgczwxyghsppm")
+ .withDescription("c")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("chygbeofiwbtfkiu")
.withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("luomaltvvp").withValue("datadhtdapkdahyn"),
- new UserProperty().withName("tixrkjogyqrmt").withValue("dataiclsxuibyfylhf")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("ubjv")
- .withDescription("rcrknnruceuwfmrc")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("bzhto")
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("qfvrqru")
.withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("dggyhpuhcc")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("qefdtpurgerybdi").withValue("datajeea"),
- new UserProperty().withName("werukuoeyyxcd").withValue("datalkkglahdwxyite"),
- new UserProperty().withName("foek").withValue("dataxhjvtfzaqnoqgfyo"),
- new UserProperty().withName("ohux").withValue("datafxkjrhgwgsba")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("mbxshrae").withValue("dataclhzmegqtzhr"),
+ new UserProperty().withName("eibku").withValue("dataolu")))
+ .withIsSequential(true)
+ .withBatchCount(797541414)
+ .withItems(new Expression().withValue("sgrcrknnr"))
+ .withActivities(
+ Arrays
+ .asList(
+ new Activity().withName("euwfmrckatnjik")
+ .withDescription("htovsyi")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("kprv")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("hcfu")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.SKIPPED, DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ekaxh")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED,
+ DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays
+ .asList(new UserProperty().withName("zsirhp").withValue("datagqdz"),
+ new UserProperty().withName("drcj").withValue("dataywbssli"),
+ new UserProperty().withName("hcpuddbzxi").withValue("dataqqeslnaoxke"),
+ new UserProperty().withName("utrlzzztg").withValue("datafzyxamyjhp")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("uvcfmtmmpvoa")
+ .withDescription("tlx")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(
+ Arrays.asList(
+ new ActivityDependency().withActivity("t")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("bnjpivoizxkh")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED,
+ DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("tih")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("jlsatoxsga")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("idcytnzy").withValue("datasydwgq"),
+ new UserProperty().withName("srlhxfmvngdrnt").withValue("datavn")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("lpuqfmrimwlpa")
+ .withDescription("wxuiakt")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(
+ Arrays
+ .asList(
+ new ActivityDependency().withActivity("hwysieoe")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("mbtvcdsl")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("qfvczuuanrjcrpx")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("tp").withValue("datazuaznsbvubbe"),
+ new UserProperty().withName("tyymljotimpuwgrn").withValue("dataxrizse")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("qmmkmqdfjeu")
+ .withDescription("qstczpsk")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("uqvywolc")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("pglcbhahxsjxurrh")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("ihlolau").withValue("datar")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(ForEachActivity.class);
- Assertions.assertEquals("mwezsirhpigq", model.name());
- Assertions.assertEquals("wdrcjyywbssli", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("bzxidqqesln", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("grjkgko", model.userProperties().get(0).name());
+ Assertions.assertEquals("wxgczwxyghsppm", model.name());
+ Assertions.assertEquals("c", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("chygbeofiwbtfkiu", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("mbxshrae", model.userProperties().get(0).name());
Assertions.assertEquals(true, model.isSequential());
- Assertions.assertEquals(1022539711, model.batchCount());
- Assertions.assertEquals("wdu", model.items().value());
- Assertions.assertEquals("krskqgokhpzvph", model.activities().get(0).name());
- Assertions.assertEquals("f", model.activities().get(0).description());
+ Assertions.assertEquals(797541414, model.batchCount());
+ Assertions.assertEquals("sgrcrknnr", model.items().value());
+ Assertions.assertEquals("euwfmrckatnjik", model.activities().get(0).name());
+ Assertions.assertEquals("htovsyi", model.activities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("kdhopzymhrfwchi", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("kprv", model.activities().get(0).dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.FAILED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("fzpkrnowexfykdi", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("zsirhp", model.activities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTypePropertiesTests.java
index 987c24b22cc6..71ab70163ac4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ForEachActivityTypePropertiesTests.java
@@ -22,102 +22,116 @@ public final class ForEachActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ForEachActivityTypeProperties model = BinaryData.fromString(
- "{\"isSequential\":false,\"batchCount\":1136169942,\"items\":{\"value\":\"mjoycyvxbrthw\"},\"activities\":[{\"type\":\"Activity\",\"name\":\"trw\",\"description\":\"ofoqrvnhcuoghvk\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"pyfjahwypdh\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Succeeded\",\"Succeeded\"],\"\":{\"xtg\":\"dataoxsga\",\"ftlbtotu\":\"dataxmxgqgquulyrtk\"}},{\"activity\":\"zasrwoxumnucqew\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Succeeded\"],\"\":{\"nz\":\"datamvcxyuemridcy\",\"ydwgq\":\"datae\",\"vn\":\"datasrlhxfmvngdrnt\"}},{\"activity\":\"hnh\",\"dependencyConditions\":[\"Skipped\",\"Completed\"],\"\":{\"qczoqp\":\"datarjyprcojwiigtd\",\"ntihlnay\":\"datapibeiftmozof\"}}],\"userProperties\":[{\"name\":\"byhouqug\",\"value\":\"datacorgnxmnvenno\"},{\"name\":\"jixoq\",\"value\":\"datajbsagwlp\"},{\"name\":\"qfmrimwlparhwx\",\"value\":\"datai\"},{\"name\":\"ktnmwlklqhwy\",\"value\":\"dataieoefwnj\"}],\"\":{\"oezcabfylsuiy\":\"datahpgavrop\",\"jqeigpylpm\":\"databildwqlxn\",\"xswiindyurwz\":\"datawdvdtzdrv\",\"lpbvponxhszrot\":\"dataxkhacvsjambtvcd\"}},{\"type\":\"Activity\",\"name\":\"nnkbekzkaoonbzi\",\"description\":\"qyzrtawjkjzvvkeh\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"bs\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Skipped\",\"Succeeded\"],\"\":{\"uuanrjcrpxlf\":\"datamtqfrdfoiqfvc\",\"kmlfcgk\":\"dataytjmlroxvsclmt\",\"bestyy\":\"dataeitphzuaznsbvu\",\"impuwgrny\":\"dataljo\"}}],\"userProperties\":[{\"name\":\"zsekfudranmdcfw\",\"value\":\"datawzjhfauubcvn\"},{\"name\":\"fxwhicacmviclhom\",\"value\":\"datahaxtegrufbz\"}],\"\":{\"qdfjeuwwq\":\"datajfzbavqmmk\",\"plbzyjuqvyw\":\"datatczpsk\",\"hbosax\":\"datalccxdctkh\",\"exgxn\":\"dataemspnzqohh\"}},{\"type\":\"Activity\",\"name\":\"fodxiy\",\"description\":\"fottycfostzd\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"bhahxs\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Completed\",\"Completed\"],\"\":{\"hujgrb\":\"datahtxgjzif\",\"gxjoimozsef\":\"datamz\"}}],\"userProperties\":[{\"name\":\"r\",\"value\":\"databdttcfwjzquwjg\"}],\"\":{\"orzbkfefxvg\":\"datalola\",\"ijzrtlfngonhmblk\":\"datakjbhsnyycya\"}},{\"type\":\"Activity\",\"name\":\"el\",\"description\":\"ki\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ynencaf\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"pmvxcrzpdqw\":\"datargwxgczwxyghs\"}},{\"activity\":\"chygbeofiwbtfkiu\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"fkukaa\":\"datasxjrafh\",\"gqhefeasm\":\"datawnqijphhuvflg\",\"pcxxpyrtajlyde\":\"datadguodoujpwqbotlv\"}}],\"userProperties\":[{\"name\":\"vrqruympo\",\"value\":\"datauxbqdwbjh\"},{\"name\":\"jzvceyxvfoyuyk\",\"value\":\"datadggyhpuhcc\"},{\"name\":\"ehndbutpt\",\"value\":\"dataabdkbkblop\"},{\"name\":\"morfzuhvycdndcz\",\"value\":\"datazsfvri\"}],\"\":{\"qcqinvkmkbtpbw\":\"datalndd\",\"drrmbxshraep\":\"datahzmqabvwbgsan\",\"qtzh\":\"datalhzme\"}}]}")
+ "{\"isSequential\":false,\"batchCount\":371055937,\"items\":{\"value\":\"jahhcbzoaryhcxmf\"},\"activities\":[{\"type\":\"Activity\",\"name\":\"mqlcooyxfrrdbdy\",\"description\":\"fmycgucccb\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"turlnbmj\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Succeeded\"],\"\":{\"hltgteg\":\"dataamoz\"}},{\"activity\":\"nguvjryfcxscrs\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Failed\",\"Failed\"],\"\":{\"j\":\"dataemkxmvqaimnfgf\",\"mrawmchcd\":\"datatbysvweuetoeqfn\"}},{\"activity\":\"gw\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"ahnimkndujywg\":\"datawfjwfkwrthpgqm\",\"ttjducosxcdhtovt\":\"datafylymuwafslyt\",\"vkiwjbufz\":\"datafwpmpapwmpd\"}}],\"userProperties\":[{\"name\":\"jfvud\",\"value\":\"datagwkyykhe\"},{\"name\":\"gapraafjxgoj\",\"value\":\"dataiupjgeb\"},{\"name\":\"suiklncqoyghrba\",\"value\":\"dataxywojux\"},{\"name\":\"fpcvblyeoyn\",\"value\":\"datahxkq\"}],\"\":{\"kkhrphvmezdfa\":\"datafuhsupifgizkv\",\"kwem\":\"datart\",\"eklgunpa\":\"dataonu\"}},{\"type\":\"Activity\",\"name\":\"w\",\"description\":\"xctdpj\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"mookh\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Skipped\",\"Completed\"],\"\":{\"iacvttdyv\":\"datatxulnntjiucno\"}},{\"activity\":\"flt\",\"dependencyConditions\":[\"Failed\"],\"\":{\"xztjece\":\"datafyllkunwinqywlvx\",\"jlkjhmugyayhp\":\"dataqhpkqkxjl\",\"soi\":\"datastlsdgiqgeeqcgu\",\"wkkykaz\":\"dataevrglzx\"}},{\"activity\":\"daqxnkdqsyhm\",\"dependencyConditions\":[\"Failed\"],\"\":{\"xjezystirrhbkzz\":\"datafgvhwkw\",\"dazmmgsx\":\"datawikqkxduhydxahj\",\"myludflf\":\"datalwofo\"}}],\"userProperties\":[{\"name\":\"whtpykfc\",\"value\":\"datacaujgacckjq\"},{\"name\":\"pj\",\"value\":\"datadbgmgxbvge\"}],\"\":{\"digx\":\"datantdynpi\",\"vliqgawen\":\"datafscsrwliuteusu\",\"q\":\"datatmvzzs\",\"oc\":\"datavwgizvvtdr\"}},{\"type\":\"Activity\",\"name\":\"zgfnphfppjzmpxam\",\"description\":\"dostvxtk\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"rbkko\",\"dependencyConditions\":[\"Completed\",\"Skipped\",\"Failed\",\"Succeeded\"],\"\":{\"dr\":\"datafzerkpaivk\"}},{\"activity\":\"kvn\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Skipped\",\"Failed\"],\"\":{\"hz\":\"datanfwslvspar\"}},{\"activity\":\"ynbxwzixmv\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Failed\",\"Failed\"],\"\":{\"xsjygig\":\"dataawzxn\",\"hpqeyzzydpv\":\"datapfokslcns\"}}],\"userProperties\":[{\"name\":\"hdjarfdfnq\",\"value\":\"datavrs\"},{\"name\":\"lhgnlbvbdq\",\"value\":\"datajcedfpubnxoohy\"},{\"name\":\"smlscvhra\",\"value\":\"dataybbor\"},{\"name\":\"dxhkdy\",\"value\":\"datadkufqzuduq\"}],\"\":{\"xtplpg\":\"datai\",\"bszcvcegl\":\"datatzugkfabvekkxl\"}},{\"type\":\"Activity\",\"name\":\"zh\",\"description\":\"vv\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"azaoytkubmv\",\"dependencyConditions\":[\"Completed\",\"Skipped\",\"Failed\",\"Failed\"],\"\":{\"iitzbyue\":\"datasqesspwutkjrqspw\"}},{\"activity\":\"umqmor\",\"dependencyConditions\":[\"Completed\",\"Skipped\"],\"\":{\"isrvlunyqen\":\"datamwd\",\"cfqzmjmf\":\"datarerzthcfnrlesgh\",\"kgklqucxewcd\":\"dataczzlkmtrrcbulvau\"}}],\"userProperties\":[{\"name\":\"jsm\",\"value\":\"datakqz\"}],\"\":{\"xzabxhmdorxbuap\":\"dataqiqydllhimvnvx\",\"oe\":\"datak\",\"cy\":\"dataicrtibad\"}}]}")
.toObject(ForEachActivityTypeProperties.class);
Assertions.assertEquals(false, model.isSequential());
- Assertions.assertEquals(1136169942, model.batchCount());
- Assertions.assertEquals("mjoycyvxbrthw", model.items().value());
- Assertions.assertEquals("trw", model.activities().get(0).name());
- Assertions.assertEquals("ofoqrvnhcuoghvk", model.activities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
+ Assertions.assertEquals(371055937, model.batchCount());
+ Assertions.assertEquals("jahhcbzoaryhcxmf", model.items().value());
+ Assertions.assertEquals("mqlcooyxfrrdbdy", model.activities().get(0).name());
+ Assertions.assertEquals("fmycgucccb", model.activities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("pyfjahwypdh", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("turlnbmj", model.activities().get(0).dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SKIPPED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("byhouqug", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("jfvud", model.activities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
ForEachActivityTypeProperties model = new ForEachActivityTypeProperties().withIsSequential(false)
- .withBatchCount(1136169942)
- .withItems(new Expression().withValue("mjoycyvxbrthw"))
+ .withBatchCount(371055937)
+ .withItems(new Expression().withValue("jahhcbzoaryhcxmf"))
.withActivities(Arrays.asList(
- new Activity().withName("trw")
- .withDescription("ofoqrvnhcuoghvk")
- .withState(ActivityState.INACTIVE)
+ new Activity().withName("mqlcooyxfrrdbdy")
+ .withDescription("fmycgucccb")
+ .withState(ActivityState.ACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("pyfjahwypdh")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("zasrwoxumnucqew")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("turlnbmj")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("hnh")
+ new ActivityDependency().withActivity("nguvjryfcxscrs")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("gw")
.withDependencyConditions(
- Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
+ Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("byhouqug").withValue("datacorgnxmnvenno"),
- new UserProperty().withName("jixoq").withValue("datajbsagwlp"),
- new UserProperty().withName("qfmrimwlparhwx").withValue("datai"),
- new UserProperty().withName("ktnmwlklqhwy").withValue("dataieoefwnj")))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("jfvud").withValue("datagwkyykhe"),
+ new UserProperty().withName("gapraafjxgoj").withValue("dataiupjgeb"),
+ new UserProperty().withName("suiklncqoyghrba").withValue("dataxywojux"),
+ new UserProperty().withName("fpcvblyeoyn").withValue("datahxkq")))
.withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("nnkbekzkaoonbzi")
- .withDescription("qyzrtawjkjzvvkeh")
+ new Activity().withName("w")
+ .withDescription("xctdpj")
.withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("bs")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.FAILED, DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("mookh")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.SKIPPED, DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("flt")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("daqxnkdqsyhm")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
.withUserProperties(
- Arrays.asList(new UserProperty().withName("zsekfudranmdcfw").withValue("datawzjhfauubcvn"),
- new UserProperty().withName("fxwhicacmviclhom").withValue("datahaxtegrufbz")))
+ Arrays.asList(new UserProperty().withName("whtpykfc").withValue("datacaujgacckjq"),
+ new UserProperty().withName("pj").withValue("datadbgmgxbvge")))
.withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("fodxiy")
- .withDescription("fottycfostzd")
+ new Activity().withName("zgfnphfppjzmpxam")
+ .withDescription("dostvxtk")
.withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("bhahxs")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SKIPPED, DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("r").withValue("databdttcfwjzquwjg")))
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("rbkko")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("kvn")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ynbxwzixmv")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("hdjarfdfnq").withValue("datavrs"),
+ new UserProperty().withName("lhgnlbvbdq").withValue("datajcedfpubnxoohy"),
+ new UserProperty().withName("smlscvhra").withValue("dataybbor"),
+ new UserProperty().withName("dxhkdy").withValue("datadkufqzuduq")))
.withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("el")
- .withDescription("ki")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ new Activity().withName("zh")
+ .withDescription("vv")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ynencaf")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("azaoytkubmv")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("chygbeofiwbtfkiu")
+ new ActivityDependency().withActivity("umqmor")
.withDependencyConditions(
- Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("vrqruympo").withValue("datauxbqdwbjh"),
- new UserProperty().withName("jzvceyxvfoyuyk").withValue("datadggyhpuhcc"),
- new UserProperty().withName("ehndbutpt").withValue("dataabdkbkblop"),
- new UserProperty().withName("morfzuhvycdndcz").withValue("datazsfvri")))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("jsm").withValue("datakqz")))
.withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(ForEachActivityTypeProperties.class);
Assertions.assertEquals(false, model.isSequential());
- Assertions.assertEquals(1136169942, model.batchCount());
- Assertions.assertEquals("mjoycyvxbrthw", model.items().value());
- Assertions.assertEquals("trw", model.activities().get(0).name());
- Assertions.assertEquals("ofoqrvnhcuoghvk", model.activities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
+ Assertions.assertEquals(371055937, model.batchCount());
+ Assertions.assertEquals("jahhcbzoaryhcxmf", model.items().value());
+ Assertions.assertEquals("mqlcooyxfrrdbdy", model.activities().get(0).name());
+ Assertions.assertEquals("fmycgucccb", model.activities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("pyfjahwypdh", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("turlnbmj", model.activities().get(0).dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SKIPPED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("byhouqug", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("jfvud", model.activities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatReadSettingsTests.java
index c771c86ef385..4bcc13b9fd14 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatReadSettingsTests.java
@@ -13,7 +13,7 @@ public final class FormatReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FormatReadSettings model = BinaryData.fromString(
- "{\"type\":\"FormatReadSettings\",\"\":{\"gdaajlhgsuqmrky\":\"datazmixwaxtnkvtzdvx\",\"hpqlxnbdjt\":\"dataovcbdsr\"}}")
+ "{\"type\":\"FormatReadSettings\",\"\":{\"ebtjg\":\"datapkooaolthowcs\",\"exar\":\"dataeuimtxmd\",\"ivftl\":\"dataukoir\",\"p\":\"dataskinmxanjguadh\"}}")
.toObject(FormatReadSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatWriteSettingsTests.java
index 47b0466a0cb1..af0753d280d5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FormatWriteSettingsTests.java
@@ -12,9 +12,9 @@
public final class FormatWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- FormatWriteSettings model = BinaryData.fromString(
- "{\"type\":\"FormatWriteSettings\",\"\":{\"eqjnouuujli\":\"datastwaa\",\"hop\":\"dataicshmqxgjzs\",\"vkcnggoc\":\"dataqxipbxs\",\"lk\":\"datawnjmiitlamfb\"}}")
- .toObject(FormatWriteSettings.class);
+ FormatWriteSettings model
+ = BinaryData.fromString("{\"type\":\"FormatWriteSettings\",\"\":{\"wwexbotbrepef\":\"datahbzetss\"}}")
+ .toObject(FormatWriteSettings.class);
}
@org.junit.jupiter.api.Test
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FtpReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FtpReadSettingsTests.java
index ac0a56eeeb46..68f238831fe7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FtpReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/FtpReadSettingsTests.java
@@ -11,23 +11,23 @@ public final class FtpReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
FtpReadSettings model = BinaryData.fromString(
- "{\"type\":\"FtpReadSettings\",\"recursive\":\"datajtcpdtd\",\"wildcardFolderPath\":\"datay\",\"wildcardFileName\":\"datazbasjckaki\",\"enablePartitionDiscovery\":\"datakajmnvbigmn\",\"partitionRootPath\":\"dataqdyco\",\"deleteFilesAfterCompletion\":\"datagkxxpkl\",\"fileListPath\":\"datavbcgs\",\"useBinaryTransfer\":\"datadaypx\",\"disableChunking\":\"dataedftkigmj\",\"maxConcurrentConnections\":\"datattvzyvzixmu\",\"disableMetricsCollection\":\"dataidivbbrtzf\",\"\":{\"uc\":\"datantnoegxoq\",\"aiexisa\":\"dataidytw\",\"oukaffzzf\":\"dataygi\",\"orvigrxmptu\":\"dataivfiypfvwyzjsi\"}}")
+ "{\"type\":\"FtpReadSettings\",\"recursive\":\"dataarmtuprqtcxqkoh\",\"wildcardFolderPath\":\"datayajkdejpar\",\"wildcardFileName\":\"datasbozfjbdyyxhjf\",\"enablePartitionDiscovery\":\"databwmrdl\",\"partitionRootPath\":\"dataklhwrikrulj\",\"deleteFilesAfterCompletion\":\"datagzffemryoia\",\"fileListPath\":\"databz\",\"useBinaryTransfer\":\"datalc\",\"disableChunking\":\"dataumvbhbli\",\"maxConcurrentConnections\":\"dataxolzinxxjfixr\",\"disableMetricsCollection\":\"datawxcaa\",\"\":{\"hacfiyrywfry\":\"dataqosgzgsgzlbunm\",\"iiarlldy\":\"datarreebjmslbxf\",\"wuebrvrh\":\"datafjdtykhsafrf\",\"ybwh\":\"dataqkfffvgbklei\"}}")
.toObject(FtpReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- FtpReadSettings model = new FtpReadSettings().withMaxConcurrentConnections("datattvzyvzixmu")
- .withDisableMetricsCollection("dataidivbbrtzf")
- .withRecursive("datajtcpdtd")
- .withWildcardFolderPath("datay")
- .withWildcardFileName("datazbasjckaki")
- .withEnablePartitionDiscovery("datakajmnvbigmn")
- .withPartitionRootPath("dataqdyco")
- .withDeleteFilesAfterCompletion("datagkxxpkl")
- .withFileListPath("datavbcgs")
- .withUseBinaryTransfer("datadaypx")
- .withDisableChunking("dataedftkigmj");
+ FtpReadSettings model = new FtpReadSettings().withMaxConcurrentConnections("dataxolzinxxjfixr")
+ .withDisableMetricsCollection("datawxcaa")
+ .withRecursive("dataarmtuprqtcxqkoh")
+ .withWildcardFolderPath("datayajkdejpar")
+ .withWildcardFileName("datasbozfjbdyyxhjf")
+ .withEnablePartitionDiscovery("databwmrdl")
+ .withPartitionRootPath("dataklhwrikrulj")
+ .withDeleteFilesAfterCompletion("datagzffemryoia")
+ .withFileListPath("databz")
+ .withUseBinaryTransfer("datalc")
+ .withDisableChunking("dataumvbhbli");
model = BinaryData.fromObject(model).toObject(FtpReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GenericDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GenericDatasetTypePropertiesTests.java
index d421b52f45ef..0c933c4130d5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GenericDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GenericDatasetTypePropertiesTests.java
@@ -10,13 +10,13 @@
public final class GenericDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- GenericDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datafzvlqquyhbce\"}")
+ GenericDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datajijzqjhljsazm\"}")
.toObject(GenericDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GenericDatasetTypeProperties model = new GenericDatasetTypeProperties().withTableName("datafzvlqquyhbce");
+ GenericDatasetTypeProperties model = new GenericDatasetTypeProperties().withTableName("datajijzqjhljsazm");
model = BinaryData.fromObject(model).toObject(GenericDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTests.java
index e648cbcaf306..c3043c73b614 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTests.java
@@ -25,72 +25,69 @@ public final class GetMetadataActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GetMetadataActivity model = BinaryData.fromString(
- "{\"type\":\"GetMetadata\",\"typeProperties\":{\"dataset\":{\"referenceName\":\"mosqhnwb\",\"parameters\":{\"hixcivjokauj\":\"datafsqruyqaqemozj\",\"wvirbshyulkhep\":\"datapclmkeswtkhfcnce\",\"bxqzczcc\":\"datamegczcpoydaifx\"}},\"fieldList\":[\"dataig\",\"datazpl\",\"dataaoiid\"],\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datasqdrugvanp\",\"disableMetricsCollection\":\"dataqrwlseeuy\",\"\":{\"pvytrzsqbckqgte\":\"datawovgwqzzugsbwqro\",\"kgyuviqeskindgm\":\"datainznkvyicj\",\"if\":\"dataebuvyuzzwphu\",\"ueikwvco\":\"dataxrnsyv\"}},\"formatSettings\":{\"type\":\"FormatReadSettings\",\"\":{\"kinutdhbmizb\":\"datamxcthrrx\"}}},\"linkedServiceName\":{\"referenceName\":\"jezufxuugvd\",\"parameters\":{\"kbmvnvfgwgo\":\"dataoycpystcmavl\",\"zoxhazafmq\":\"datafdyk\",\"ammpeakdhebzquq\":\"databifpc\",\"fjwm\":\"datagjxklojdydha\"}},\"policy\":{\"timeout\":\"datagjihnxoxjghumv\",\"retry\":\"databhogllvfealcju\",\"retryIntervalInSeconds\":1732670055,\"secureInput\":false,\"secureOutput\":false,\"\":{\"nxsyh\":\"datanovbgdbao\",\"inrymzlq\":\"datailqojdmzejcpzzq\",\"mvg\":\"datarcivxaq\"}},\"name\":\"qtkcvnyikyexwfsi\",\"description\":\"x\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"ztns\",\"dependencyConditions\":[\"Failed\"],\"\":{\"h\":\"datakklz\",\"tcxhpntewvfvs\":\"datavtivefsr\",\"dervnnfieaqbvg\":\"datadmcoxobrv\",\"ubqemrxmr\":\"dataehggeeagbrslbzc\"}},{\"activity\":\"be\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\"],\"\":{\"vgagdnzvo\":\"datawqnwxohb\",\"zcpifasifdtiocsf\":\"datarnqnurunky\",\"borynmadtyhm\":\"datacyyicascvcmthu\"}},{\"activity\":\"phoem\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"bqij\":\"dataphncf\",\"xhmtxpxdtmrwjk\":\"dataqfoatqnhr\",\"bkdhwadnccunrviq\":\"datatiznvijdtmjy\",\"sliou\":\"dataz\"}}],\"userProperties\":[{\"name\":\"xqnpnpggbu\",\"value\":\"datajw\"},{\"name\":\"rgq\",\"value\":\"datadnmuirtkqztkx\"},{\"name\":\"hixfuuzaczmejf\",\"value\":\"dataiegpdhityt\"}],\"\":{\"chbvejgfx\":\"datawdskocmqhzys\",\"cyngdgka\":\"datajqevmzhk\",\"hrlb\":\"datanxy\"}}")
+ "{\"type\":\"GetMetadata\",\"typeProperties\":{\"dataset\":{\"referenceName\":\"khe\",\"parameters\":{\"fxmbxqzczcc\":\"dataegczcpoyda\",\"aoiid\":\"datalpigpzpl\",\"gvanpjv\":\"dataknsqdr\",\"gwq\":\"datarwlseeuyxxrwo\"}},\"fieldList\":[\"datagsbwq\",\"dataotpvyt\",\"datazsqbckq\",\"datateminzn\"],\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"dataicjzkgyuv\",\"disableMetricsCollection\":\"dataeskindgmk\",\"\":{\"lxrnsyvmueik\":\"datavyuzzwphuli\",\"im\":\"datavcogq\"}},\"formatSettings\":{\"type\":\"FormatReadSettings\",\"\":{\"nu\":\"datarrxrk\",\"ufxuug\":\"datadhbmizbevje\",\"cmavln\":\"datadbpjoycpys\"}}},\"linkedServiceName\":{\"referenceName\":\"mvnvfg\",\"parameters\":{\"kezoxhazafmq\":\"dataxfd\",\"ammpeakdhebzquq\":\"databifpc\"}},\"policy\":{\"timeout\":\"dataxklojd\",\"retry\":\"datahajfj\",\"retryIntervalInSeconds\":1912893320,\"secureInput\":false,\"secureOutput\":true,\"\":{\"o\":\"datanxoxjghumvptb\",\"cjuzzzil\":\"datallvfea\",\"novbgdbao\":\"datauc\",\"ilqojdmzejcpzzq\":\"datanxsyh\"}},\"name\":\"inrymzlq\",\"description\":\"civxaqzmvgxqt\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"ye\",\"dependencyConditions\":[\"Completed\",\"Succeeded\"],\"\":{\"utesqkklzyhav\":\"datagxelzuvdyztn\",\"ltc\":\"dataivefs\",\"vsidmcoxobrvzder\":\"datahpntewv\"}},{\"activity\":\"nnfi\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"brslbzcyubqemrxm\":\"dataguehggeea\",\"wwqnwxohbmvg\":\"dataibexaxu\",\"runkyuzcpi\":\"datagdnzvohrnqn\",\"fdtiocs\":\"dataas\"}}],\"userProperties\":[{\"name\":\"yyicascv\",\"value\":\"datamthukboryn\"},{\"name\":\"adtyhmoph\",\"value\":\"dataemhvnqwdphncftbq\"},{\"name\":\"jeqfoatqnhrhxhmt\",\"value\":\"datapxdtmrwjknt\"},{\"name\":\"znvijdtmjybbkdh\",\"value\":\"dataadnccunrviqrzw\"}],\"\":{\"exqnpnpggbua\":\"dataouc\",\"qztkxfhixfuuzacz\":\"datawrrgqudnmuirt\",\"d\":\"dataejfiieg\",\"qhzyswchbvejg\":\"dataitytketwdskoc\"}}")
.toObject(GetMetadataActivity.class);
- Assertions.assertEquals("qtkcvnyikyexwfsi", model.name());
- Assertions.assertEquals("x", model.description());
+ Assertions.assertEquals("inrymzlq", model.name());
+ Assertions.assertEquals("civxaqzmvgxqt", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("ztns", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("xqnpnpggbu", model.userProperties().get(0).name());
- Assertions.assertEquals("jezufxuugvd", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1732670055, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("ye", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("yyicascv", model.userProperties().get(0).name());
+ Assertions.assertEquals("mvnvfg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1912893320, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("mosqhnwb", model.dataset().referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("khe", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GetMetadataActivity model = new GetMetadataActivity().withName("qtkcvnyikyexwfsi")
- .withDescription("x")
+ GetMetadataActivity model = new GetMetadataActivity().withName("inrymzlq")
+ .withDescription("civxaqzmvgxqt")
.withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ztns")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("be")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("phoem")
+ new ActivityDependency().withActivity("ye")
.withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("nnfi")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("xqnpnpggbu").withValue("datajw"),
- new UserProperty().withName("rgq").withValue("datadnmuirtkqztkx"),
- new UserProperty().withName("hixfuuzaczmejf").withValue("dataiegpdhityt")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("jezufxuugvd")
- .withParameters(mapOf("kbmvnvfgwgo", "dataoycpystcmavl", "zoxhazafmq", "datafdyk", "ammpeakdhebzquq",
- "databifpc", "fjwm", "datagjxklojdydha")))
- .withPolicy(new ActivityPolicy().withTimeout("datagjihnxoxjghumv")
- .withRetry("databhogllvfealcju")
- .withRetryIntervalInSeconds(1732670055)
+ .withUserProperties(Arrays.asList(new UserProperty().withName("yyicascv").withValue("datamthukboryn"),
+ new UserProperty().withName("adtyhmoph").withValue("dataemhvnqwdphncftbq"),
+ new UserProperty().withName("jeqfoatqnhrhxhmt").withValue("datapxdtmrwjknt"),
+ new UserProperty().withName("znvijdtmjybbkdh").withValue("dataadnccunrviqrzw")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mvnvfg")
+ .withParameters(mapOf("kezoxhazafmq", "dataxfd", "ammpeakdhebzquq", "databifpc")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataxklojd")
+ .withRetry("datahajfj")
+ .withRetryIntervalInSeconds(1912893320)
.withSecureInput(false)
- .withSecureOutput(false)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withDataset(new DatasetReference().withReferenceName("mosqhnwb")
- .withParameters(mapOf("hixcivjokauj", "datafsqruyqaqemozj", "wvirbshyulkhep", "datapclmkeswtkhfcnce",
- "bxqzczcc", "datamegczcpoydaifx")))
- .withFieldList(Arrays.asList("dataig", "datazpl", "dataaoiid"))
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datasqdrugvanp")
- .withDisableMetricsCollection("dataqrwlseeuy")
+ .withDataset(new DatasetReference().withReferenceName("khe")
+ .withParameters(mapOf("fxmbxqzczcc", "dataegczcpoyda", "aoiid", "datalpigpzpl", "gvanpjv", "dataknsqdr",
+ "gwq", "datarwlseeuyxxrwo")))
+ .withFieldList(Arrays.asList("datagsbwq", "dataotpvyt", "datazsqbckq", "datateminzn"))
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("dataicjzkgyuv")
+ .withDisableMetricsCollection("dataeskindgmk")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
.withFormatSettings(new FormatReadSettings().withAdditionalProperties(mapOf("type", "FormatReadSettings")));
model = BinaryData.fromObject(model).toObject(GetMetadataActivity.class);
- Assertions.assertEquals("qtkcvnyikyexwfsi", model.name());
- Assertions.assertEquals("x", model.description());
+ Assertions.assertEquals("inrymzlq", model.name());
+ Assertions.assertEquals("civxaqzmvgxqt", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("ztns", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("xqnpnpggbu", model.userProperties().get(0).name());
- Assertions.assertEquals("jezufxuugvd", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1732670055, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("ye", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("yyicascv", model.userProperties().get(0).name());
+ Assertions.assertEquals("mvnvfg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1912893320, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("mosqhnwb", model.dataset().referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("khe", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTypePropertiesTests.java
index 000c931b0e1d..74a1be4296d0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GetMetadataActivityTypePropertiesTests.java
@@ -18,24 +18,24 @@ public final class GetMetadataActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GetMetadataActivityTypeProperties model = BinaryData.fromString(
- "{\"dataset\":{\"referenceName\":\"hd\",\"parameters\":{\"edgwghqqiu\":\"datadlvcbcxbiisnhqqq\",\"vroopksmjpopi\":\"dataetmqzuenbll\",\"wqspnrcuvlfzdk\":\"dataaxk\"}},\"fieldList\":[\"dataupacahlsavin\",\"dataorabspfinyijm\",\"dataqgmhfvlbd\",\"datadhedmfidro\"],\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"dataucwmdmbysvqbg\",\"disableMetricsCollection\":\"datafzheyxccxeusioaw\",\"\":{\"icwbquppkzuxsbbm\":\"datae\",\"y\":\"datafut\",\"l\":\"datahelyopobg\",\"ffgtqhghygz\":\"dataukiwjezadkfmp\"}},\"formatSettings\":{\"type\":\"FormatReadSettings\",\"\":{\"ucxmybuqjpgbi\":\"datargmlaerx\",\"zfyin\":\"dataaxga\"}}}")
+ "{\"dataset\":{\"referenceName\":\"xvjqevmzhkocyngd\",\"parameters\":{\"lvcbcxb\":\"datapnxylhrlbohdxln\",\"iuuetmqzuen\":\"dataisnhqqqaedgwghq\",\"mj\":\"datallqvroopk\"}},\"fieldList\":[\"dataibaxky\",\"dataqspnrcuvlfzdkpfe\"],\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datacahlsavinoora\",\"disableMetricsCollection\":\"datapfinyijmwqgmhfv\",\"\":{\"ucwmdmbysvqbg\":\"datazdhedmfidropf\"}},\"formatSettings\":{\"type\":\"FormatReadSettings\",\"\":{\"xeusioawrorexi\":\"dataheyxc\",\"tmyc\":\"datawbquppkzuxsbbmxf\",\"ezadkfmpiffgtqhg\":\"dataelyopobgzluukiw\"}}}")
.toObject(GetMetadataActivityTypeProperties.class);
- Assertions.assertEquals("hd", model.dataset().referenceName());
+ Assertions.assertEquals("xvjqevmzhkocyngd", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
GetMetadataActivityTypeProperties model = new GetMetadataActivityTypeProperties()
- .withDataset(new DatasetReference().withReferenceName("hd")
- .withParameters(mapOf("edgwghqqiu", "datadlvcbcxbiisnhqqq", "vroopksmjpopi", "dataetmqzuenbll",
- "wqspnrcuvlfzdk", "dataaxk")))
- .withFieldList(Arrays.asList("dataupacahlsavin", "dataorabspfinyijm", "dataqgmhfvlbd", "datadhedmfidro"))
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("dataucwmdmbysvqbg")
- .withDisableMetricsCollection("datafzheyxccxeusioaw")
+ .withDataset(new DatasetReference().withReferenceName("xvjqevmzhkocyngd")
+ .withParameters(mapOf("lvcbcxb", "datapnxylhrlbohdxln", "iuuetmqzuen", "dataisnhqqqaedgwghq", "mj",
+ "datallqvroopk")))
+ .withFieldList(Arrays.asList("dataibaxky", "dataqspnrcuvlfzdkpfe"))
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datacahlsavinoora")
+ .withDisableMetricsCollection("datapfinyijmwqgmhfv")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
.withFormatSettings(new FormatReadSettings().withAdditionalProperties(mapOf("type", "FormatReadSettings")));
model = BinaryData.fromObject(model).toObject(GetMetadataActivityTypeProperties.class);
- Assertions.assertEquals("hd", model.dataset().referenceName());
+ Assertions.assertEquals("xvjqevmzhkocyngd", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersCreateOrUpdateWithResponseMockTests.java
index 3e148b9dd41f..0dfa026ff519 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersCreateOrUpdateWithResponseMockTests.java
@@ -25,7 +25,7 @@ public final class GlobalParametersCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"cdzul\":{\"type\":\"Float\",\"value\":\"datadvey\"},\"xzszhvjfijxthojb\":{\"type\":\"String\",\"value\":\"datafxedm\"},\"qyapn\":{\"type\":\"Int\",\"value\":\"dataipc\"},\"dwdaugdgvshf\":{\"type\":\"Int\",\"value\":\"databyhdtjynus\"}},\"name\":\"ii\",\"type\":\"ki\",\"etag\":\"okjuehcrywwfnsr\",\"id\":\"jadnwafjiba\"}";
+ = "{\"properties\":{\"glcktraeraql\":{\"type\":\"Object\",\"value\":\"datathfas\"}},\"name\":\"yhwdogchdqtlbnkr\",\"type\":\"oxlwpeksrhkmzs\",\"etag\":\"p\",\"id\":\"sbp\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -35,14 +35,14 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
GlobalParameterResource response = manager.globalParameters()
- .define("agsx")
- .withExistingFactory("jh", "emlw")
- .withProperties(mapOf("utu",
- new GlobalParameterSpecification().withType(GlobalParameterType.OBJECT).withValue("dataaugenpipptpre")))
+ .define("aqlbdez")
+ .withExistingFactory("javpmokaqnuycd", "ymbefvuutlirz")
+ .withProperties(mapOf("ycdryjgxwd",
+ new GlobalParameterSpecification().withType(GlobalParameterType.INT).withValue("datauhearhkchyugj")))
.create();
- Assertions.assertEquals("jadnwafjiba", response.id());
- Assertions.assertEquals(GlobalParameterType.FLOAT, response.properties().get("cdzul").type());
+ Assertions.assertEquals("sbp", response.id());
+ Assertions.assertEquals(GlobalParameterType.OBJECT, response.properties().get("glcktraeraql").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersDeleteWithResponseMockTests.java
index f34cf3ed7efc..d4807bbad892 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersDeleteWithResponseMockTests.java
@@ -27,7 +27,7 @@ public void testDeleteWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.globalParameters().deleteWithResponse("g", "xrifyr", "prgiaeqcgdl", com.azure.core.util.Context.NONE);
+ manager.globalParameters().deleteWithResponse("yrs", "ifcwjbyfdjzefk", "c", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersGetWithResponseMockTests.java
index 087ebd22315d..84cd9eeacce5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersGetWithResponseMockTests.java
@@ -22,7 +22,7 @@ public final class GlobalParametersGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"r\":{\"type\":\"Float\",\"value\":\"datarphdakwwiezeut\"}},\"name\":\"wmo\",\"type\":\"qlwzatvnejlocmql\",\"etag\":\"lpqlwtxshvozh\",\"id\":\"lmwvcehkvafcjekt\"}";
+ = "{\"properties\":{\"uzyyniv\":{\"type\":\"Int\",\"value\":\"datanlpjivtzs\"},\"mtxvnelw\":{\"type\":\"Array\",\"value\":\"dataqiijkvops\"},\"ytdborujflt\":{\"type\":\"String\",\"value\":\"datadm\"},\"gugvrwnweiwkbkh\":{\"type\":\"Bool\",\"value\":\"datawfwlfq\"}},\"name\":\"qacc\",\"type\":\"bdjott\",\"etag\":\"kqsxgaojwulat\",\"id\":\"jzv\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,11 +31,10 @@ public void testGetWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- GlobalParameterResource response = manager.globalParameters()
- .getWithResponse("dpqkcbflzzd", "frewirrsuf", "tmseuqg", com.azure.core.util.Context.NONE)
- .getValue();
+ GlobalParameterResource response
+ = manager.globalParameters().getWithResponse("lf", "ftz", "g", com.azure.core.util.Context.NONE).getValue();
- Assertions.assertEquals("lmwvcehkvafcjekt", response.id());
- Assertions.assertEquals(GlobalParameterType.FLOAT, response.properties().get("r").type());
+ Assertions.assertEquals("jzv", response.id());
+ Assertions.assertEquals(GlobalParameterType.INT, response.properties().get("uzyyniv").type());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersListByFactoryMockTests.java
index 234bb4f76aec..c7eaa46535c8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GlobalParametersListByFactoryMockTests.java
@@ -23,7 +23,7 @@ public final class GlobalParametersListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"cwngg\":{\"type\":\"Int\",\"value\":\"datamjxxov\"},\"papzb\":{\"type\":\"Int\",\"value\":\"datajbgy\"},\"izoamttxyddkvi\":{\"type\":\"Float\",\"value\":\"datafuac\"}},\"name\":\"bbn\",\"type\":\"gzlicytfpy\",\"etag\":\"ednous\",\"id\":\"ljl\"}]}";
+ = "{\"value\":[{\"properties\":{\"gjkzulihdhfcc\":{\"type\":\"Float\",\"value\":\"datas\"},\"ilhcca\":{\"type\":\"Float\",\"value\":\"datahztqiaydmblpdjtl\"},\"ydcslyd\":{\"type\":\"Int\",\"value\":\"dataiifvindcakansjrz\"},\"iyngupphvo\":{\"type\":\"Array\",\"value\":\"datawtkce\"}},\"name\":\"ocjsadbuvvpdj\",\"type\":\"nndvvgs\",\"etag\":\"vz\",\"id\":\"dfikduwqkhmabgzc\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -33,9 +33,10 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.globalParameters().listByFactory("ukveknwldqjlgzc", "rh", com.azure.core.util.Context.NONE);
+ = manager.globalParameters().listByFactory("tbflechgiqxknjr", "rvnq", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("ljl", response.iterator().next().id());
- Assertions.assertEquals(GlobalParameterType.INT, response.iterator().next().properties().get("cwngg").type());
+ Assertions.assertEquals("dfikduwqkhmabgzc", response.iterator().next().id());
+ Assertions.assertEquals(GlobalParameterType.FLOAT,
+ response.iterator().next().properties().get("gjkzulihdhfcc").type());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsObjectDatasetTests.java
index c51bfcdb3442..97f4ea5f05f9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsObjectDatasetTests.java
@@ -19,36 +19,31 @@ public final class GoogleAdWordsObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleAdWordsObjectDataset model = BinaryData.fromString(
- "{\"type\":\"GoogleAdWordsObject\",\"typeProperties\":{\"tableName\":\"datapdcbgrufsdbkuxkd\"},\"description\":\"m\",\"structure\":\"dataivxwkscwbshfih\",\"schema\":\"datamsceylaulpue\",\"linkedServiceName\":{\"referenceName\":\"yi\",\"parameters\":{\"xdslspgnndef\":\"datatye\",\"yltaprqtfkmvzrk\":\"datahsbyhwlvsv\"}},\"parameters\":{\"ukkmv\":{\"type\":\"Array\",\"defaultValue\":\"datadwfcuhbgftfv\"},\"hhxlsube\":{\"type\":\"Bool\",\"defaultValue\":\"dataegpdqrjylwqqsem\"},\"wyktdp\":{\"type\":\"Int\",\"defaultValue\":\"databejrd\"},\"jkykqf\":{\"type\":\"Object\",\"defaultValue\":\"dataufifnjwjh\"}},\"annotations\":[\"datacyk\"],\"folder\":{\"name\":\"smkb\"},\"\":{\"ejnoignyd\":\"datarihpjaxhcb\",\"bnmrmhkipjardvdp\":\"datakrnp\",\"pbie\":\"datagwdxmiael\",\"nddvjlpbj\":\"datal\"}}")
+ "{\"type\":\"GoogleAdWordsObject\",\"typeProperties\":{\"tableName\":\"datainrkj\"},\"description\":\"gzfsu\",\"structure\":\"dataybhozlsbufnhb\",\"schema\":\"datantpoe\",\"linkedServiceName\":{\"referenceName\":\"ytrsljzmzui\",\"parameters\":{\"p\":\"datagsxzn\",\"ma\":\"datamkqbylbbnjldicq\"}},\"parameters\":{\"fzoidy\":{\"type\":\"Int\",\"defaultValue\":\"dataenitvkyahfo\"}},\"annotations\":[\"datarev\"],\"folder\":{\"name\":\"kfalw\"},\"\":{\"ucnusnylfhicrj\":\"datachcayvqbeq\"}}")
.toObject(GoogleAdWordsObjectDataset.class);
- Assertions.assertEquals("m", model.description());
- Assertions.assertEquals("yi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ukkmv").type());
- Assertions.assertEquals("smkb", model.folder().name());
+ Assertions.assertEquals("gzfsu", model.description());
+ Assertions.assertEquals("ytrsljzmzui", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("fzoidy").type());
+ Assertions.assertEquals("kfalw", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GoogleAdWordsObjectDataset model = new GoogleAdWordsObjectDataset().withDescription("m")
- .withStructure("dataivxwkscwbshfih")
- .withSchema("datamsceylaulpue")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("yi")
- .withParameters(mapOf("xdslspgnndef", "datatye", "yltaprqtfkmvzrk", "datahsbyhwlvsv")))
- .withParameters(mapOf("ukkmv",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datadwfcuhbgftfv"),
- "hhxlsube",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataegpdqrjylwqqsem"),
- "wyktdp", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("databejrd"),
- "jkykqf",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataufifnjwjh")))
- .withAnnotations(Arrays.asList("datacyk"))
- .withFolder(new DatasetFolder().withName("smkb"))
- .withTableName("datapdcbgrufsdbkuxkd");
+ GoogleAdWordsObjectDataset model = new GoogleAdWordsObjectDataset().withDescription("gzfsu")
+ .withStructure("dataybhozlsbufnhb")
+ .withSchema("datantpoe")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ytrsljzmzui")
+ .withParameters(mapOf("p", "datagsxzn", "ma", "datamkqbylbbnjldicq")))
+ .withParameters(mapOf("fzoidy",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataenitvkyahfo")))
+ .withAnnotations(Arrays.asList("datarev"))
+ .withFolder(new DatasetFolder().withName("kfalw"))
+ .withTableName("datainrkj");
model = BinaryData.fromObject(model).toObject(GoogleAdWordsObjectDataset.class);
- Assertions.assertEquals("m", model.description());
- Assertions.assertEquals("yi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ukkmv").type());
- Assertions.assertEquals("smkb", model.folder().name());
+ Assertions.assertEquals("gzfsu", model.description());
+ Assertions.assertEquals("ytrsljzmzui", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("fzoidy").type());
+ Assertions.assertEquals("kfalw", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsSourceTests.java
index 9be5e9d4b532..9f14d9eade9a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleAdWordsSourceTests.java
@@ -11,19 +11,19 @@ public final class GoogleAdWordsSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleAdWordsSource model = BinaryData.fromString(
- "{\"type\":\"GoogleAdWordsSource\",\"query\":\"datalymmhzvnetecfy\",\"queryTimeout\":\"datafkcwfpoaflgkzgzx\",\"additionalColumns\":\"datavvfkqbgkssygdv\",\"sourceRetryCount\":\"databbd\",\"sourceRetryWait\":\"datal\",\"maxConcurrentConnections\":\"datapwpsxygrniq\",\"disableMetricsCollection\":\"datapsebaz\",\"\":{\"imtu\":\"datarjroqgnsfzrra\"}}")
+ "{\"type\":\"GoogleAdWordsSource\",\"query\":\"dataxkwrvtlb\",\"queryTimeout\":\"datakbdtmr\",\"additionalColumns\":\"datatuzfhvb\",\"sourceRetryCount\":\"datai\",\"sourceRetryWait\":\"datauluilgmovadn\",\"maxConcurrentConnections\":\"datasmjxgqsbjc\",\"disableMetricsCollection\":\"dataaruvbzcqgtzxtlr\",\"\":{\"pswlepttabrkn\":\"datadznvjgovyqp\",\"keuyxgpcrvvmrdl\":\"datafw\",\"ysdharswhq\":\"datakpznoveabwpaiqik\",\"nndfplksdiehraj\":\"datarpdxnrdvtvtyqlt\"}}")
.toObject(GoogleAdWordsSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GoogleAdWordsSource model = new GoogleAdWordsSource().withSourceRetryCount("databbd")
- .withSourceRetryWait("datal")
- .withMaxConcurrentConnections("datapwpsxygrniq")
- .withDisableMetricsCollection("datapsebaz")
- .withQueryTimeout("datafkcwfpoaflgkzgzx")
- .withAdditionalColumns("datavvfkqbgkssygdv")
- .withQuery("datalymmhzvnetecfy");
+ GoogleAdWordsSource model = new GoogleAdWordsSource().withSourceRetryCount("datai")
+ .withSourceRetryWait("datauluilgmovadn")
+ .withMaxConcurrentConnections("datasmjxgqsbjc")
+ .withDisableMetricsCollection("dataaruvbzcqgtzxtlr")
+ .withQueryTimeout("datakbdtmr")
+ .withAdditionalColumns("datatuzfhvb")
+ .withQuery("dataxkwrvtlb");
model = BinaryData.fromObject(model).toObject(GoogleAdWordsSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryDatasetTypePropertiesTests.java
index bba0f1430865..73f1fdd3a349 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryDatasetTypePropertiesTests.java
@@ -10,16 +10,17 @@
public final class GoogleBigQueryDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- GoogleBigQueryDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datax\",\"table\":\"dataxlawmvdyqab\",\"dataset\":\"dataopx\"}")
- .toObject(GoogleBigQueryDatasetTypeProperties.class);
+ GoogleBigQueryDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"datahxfpzc\",\"table\":\"datadq\",\"dataset\":\"datadxjvvlyibweuaugt\"}")
+ .toObject(GoogleBigQueryDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GoogleBigQueryDatasetTypeProperties model = new GoogleBigQueryDatasetTypeProperties().withTableName("datax")
- .withTable("dataxlawmvdyqab")
- .withDataset("dataopx");
+ GoogleBigQueryDatasetTypeProperties model
+ = new GoogleBigQueryDatasetTypeProperties().withTableName("datahxfpzc")
+ .withTable("datadq")
+ .withDataset("datadxjvvlyibweuaugt");
model = BinaryData.fromObject(model).toObject(GoogleBigQueryDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryObjectDatasetTests.java
index ded8c1bffacf..2b21104a812c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryObjectDatasetTests.java
@@ -19,35 +19,39 @@ public final class GoogleBigQueryObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleBigQueryObjectDataset model = BinaryData.fromString(
- "{\"type\":\"GoogleBigQueryObject\",\"typeProperties\":{\"tableName\":\"datajwxgvtkjct\",\"table\":\"datapeawzzkvfccozv\",\"dataset\":\"datasphtraitrmsukxtu\"},\"description\":\"gcptct\",\"structure\":\"dataoegyc\",\"schema\":\"dataem\",\"linkedServiceName\":{\"referenceName\":\"vrcclclfkfv\",\"parameters\":{\"vpoip\":\"datammw\",\"fzvvpaysqwhzdc\":\"dataylxtebvse\",\"dblk\":\"dataa\"}},\"parameters\":{\"fvxuosqpffapjpj\":{\"type\":\"Array\",\"defaultValue\":\"datapvdfmoqqc\"},\"yjzua\":{\"type\":\"Object\",\"defaultValue\":\"datazzjsnyfo\"},\"r\":{\"type\":\"Bool\",\"defaultValue\":\"dataubeqkitt\"}},\"annotations\":[\"dataxsoangu\",\"datab\",\"datahogsezre\"],\"folder\":{\"name\":\"gpdtyzpx\"},\"\":{\"hskvsdfvhrypezam\":\"datawkejmgemudup\",\"keq\":\"datapkapvnpeukgnmf\",\"rowsh\":\"dataitromlcsvktfp\"}}")
+ "{\"type\":\"GoogleBigQueryObject\",\"typeProperties\":{\"tableName\":\"datablt\",\"table\":\"datavnpbgcesfddfclmo\",\"dataset\":\"datarofofkbcjzzw\"},\"description\":\"oblbtdqzhixccnkf\",\"structure\":\"datagvyoxmyqzyqe\",\"schema\":\"databbzdsluokcevox\",\"linkedServiceName\":{\"referenceName\":\"ddpwmgw\",\"parameters\":{\"vvvgyphheovejk\":\"datakfjvqglaxsei\",\"thrtzpuv\":\"dataaleczt\"}},\"parameters\":{\"zembqqiehdhjofyw\":{\"type\":\"String\",\"defaultValue\":\"datarqefnquollouurm\"},\"hvpaglyyhrgma\":{\"type\":\"Float\",\"defaultValue\":\"dataxoxlorxgslqcxu\"},\"tocrbfgqicmdrgcu\":{\"type\":\"Array\",\"defaultValue\":\"datamlutyjukkedp\"},\"cmljzksqimybqj\":{\"type\":\"Bool\",\"defaultValue\":\"datavkrwrjcqh\"}},\"annotations\":[\"dataomhcaqpv\",\"dataszopeuku\"],\"folder\":{\"name\":\"wbsskgqjemo\"},\"\":{\"gipdzym\":\"datafsjbpwjwz\"}}")
.toObject(GoogleBigQueryObjectDataset.class);
- Assertions.assertEquals("gcptct", model.description());
- Assertions.assertEquals("vrcclclfkfv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("fvxuosqpffapjpj").type());
- Assertions.assertEquals("gpdtyzpx", model.folder().name());
+ Assertions.assertEquals("oblbtdqzhixccnkf", model.description());
+ Assertions.assertEquals("ddpwmgw", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("zembqqiehdhjofyw").type());
+ Assertions.assertEquals("wbsskgqjemo", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GoogleBigQueryObjectDataset model = new GoogleBigQueryObjectDataset().withDescription("gcptct")
- .withStructure("dataoegyc")
- .withSchema("dataem")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vrcclclfkfv")
- .withParameters(mapOf("vpoip", "datammw", "fzvvpaysqwhzdc", "dataylxtebvse", "dblk", "dataa")))
- .withParameters(mapOf("fvxuosqpffapjpj",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datapvdfmoqqc"), "yjzua",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datazzjsnyfo"), "r",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataubeqkitt")))
- .withAnnotations(Arrays.asList("dataxsoangu", "datab", "datahogsezre"))
- .withFolder(new DatasetFolder().withName("gpdtyzpx"))
- .withTableName("datajwxgvtkjct")
- .withTable("datapeawzzkvfccozv")
- .withDataset("datasphtraitrmsukxtu");
+ GoogleBigQueryObjectDataset model = new GoogleBigQueryObjectDataset().withDescription("oblbtdqzhixccnkf")
+ .withStructure("datagvyoxmyqzyqe")
+ .withSchema("databbzdsluokcevox")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ddpwmgw")
+ .withParameters(mapOf("vvvgyphheovejk", "datakfjvqglaxsei", "thrtzpuv", "dataaleczt")))
+ .withParameters(mapOf("zembqqiehdhjofyw",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datarqefnquollouurm"),
+ "hvpaglyyhrgma",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataxoxlorxgslqcxu"),
+ "tocrbfgqicmdrgcu",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datamlutyjukkedp"),
+ "cmljzksqimybqj",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datavkrwrjcqh")))
+ .withAnnotations(Arrays.asList("dataomhcaqpv", "dataszopeuku"))
+ .withFolder(new DatasetFolder().withName("wbsskgqjemo"))
+ .withTableName("datablt")
+ .withTable("datavnpbgcesfddfclmo")
+ .withDataset("datarofofkbcjzzw");
model = BinaryData.fromObject(model).toObject(GoogleBigQueryObjectDataset.class);
- Assertions.assertEquals("gcptct", model.description());
- Assertions.assertEquals("vrcclclfkfv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("fvxuosqpffapjpj").type());
- Assertions.assertEquals("gpdtyzpx", model.folder().name());
+ Assertions.assertEquals("oblbtdqzhixccnkf", model.description());
+ Assertions.assertEquals("ddpwmgw", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("zembqqiehdhjofyw").type());
+ Assertions.assertEquals("wbsskgqjemo", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQuerySourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQuerySourceTests.java
index b199598ba423..24bccc0e248e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQuerySourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQuerySourceTests.java
@@ -11,19 +11,19 @@ public final class GoogleBigQuerySourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleBigQuerySource model = BinaryData.fromString(
- "{\"type\":\"GoogleBigQuerySource\",\"query\":\"datavijdr\",\"queryTimeout\":\"datayqvhz\",\"additionalColumns\":\"datayvhrenozl\",\"sourceRetryCount\":\"dataqfghlosho\",\"sourceRetryWait\":\"datakpcmtsbandesalv\",\"maxConcurrentConnections\":\"datawrljmlo\",\"disableMetricsCollection\":\"datatzvtfyqe\",\"\":{\"xhcygfg\":\"databsyni\",\"aosttbwap\":\"datamdbazggr\"}}")
+ "{\"type\":\"GoogleBigQuerySource\",\"query\":\"dataeydmeuimlhyze\",\"queryTimeout\":\"dataivkzrvya\",\"additionalColumns\":\"dataqgyui\",\"sourceRetryCount\":\"dataelyjduzapnopoto\",\"sourceRetryWait\":\"datarrqcaglyt\",\"maxConcurrentConnections\":\"datacbdpczmzuwr\",\"disableMetricsCollection\":\"datahfwce\",\"\":{\"cyfccnwmdpbso\":\"dataaqaviqskylwpq\",\"fxpveruuckrzw\":\"datakn\"}}")
.toObject(GoogleBigQuerySource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GoogleBigQuerySource model = new GoogleBigQuerySource().withSourceRetryCount("dataqfghlosho")
- .withSourceRetryWait("datakpcmtsbandesalv")
- .withMaxConcurrentConnections("datawrljmlo")
- .withDisableMetricsCollection("datatzvtfyqe")
- .withQueryTimeout("datayqvhz")
- .withAdditionalColumns("datayvhrenozl")
- .withQuery("datavijdr");
+ GoogleBigQuerySource model = new GoogleBigQuerySource().withSourceRetryCount("dataelyjduzapnopoto")
+ .withSourceRetryWait("datarrqcaglyt")
+ .withMaxConcurrentConnections("datacbdpczmzuwr")
+ .withDisableMetricsCollection("datahfwce")
+ .withQueryTimeout("dataivkzrvya")
+ .withAdditionalColumns("dataqgyui")
+ .withQuery("dataeydmeuimlhyze");
model = BinaryData.fromObject(model).toObject(GoogleBigQuerySource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2DatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2DatasetTypePropertiesTests.java
index f6173a9e2540..e100f8ede502 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2DatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2DatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class GoogleBigQueryV2DatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleBigQueryV2DatasetTypeProperties model
- = BinaryData.fromString("{\"table\":\"dataddpwmgw\",\"dataset\":\"dataukfjvqgl\"}")
+ = BinaryData.fromString("{\"table\":\"dataowqrzvuxn\",\"dataset\":\"datauohshzultdbvm\"}")
.toObject(GoogleBigQueryV2DatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
GoogleBigQueryV2DatasetTypeProperties model
- = new GoogleBigQueryV2DatasetTypeProperties().withTable("dataddpwmgw").withDataset("dataukfjvqgl");
+ = new GoogleBigQueryV2DatasetTypeProperties().withTable("dataowqrzvuxn").withDataset("datauohshzultdbvm");
model = BinaryData.fromObject(model).toObject(GoogleBigQueryV2DatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2ObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2ObjectDatasetTests.java
index 87f8220e2236..d3442cbb1a54 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2ObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2ObjectDatasetTests.java
@@ -19,36 +19,35 @@ public final class GoogleBigQueryV2ObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleBigQueryV2ObjectDataset model = BinaryData.fromString(
- "{\"type\":\"GoogleBigQueryV2Object\",\"typeProperties\":{\"table\":\"datamllznyjyuw\",\"dataset\":\"datazwgdpvhwiril\"},\"description\":\"qtr\",\"structure\":\"datadoxdegacdedpkw\",\"schema\":\"dataobp\",\"linkedServiceName\":{\"referenceName\":\"dcidpdaq\",\"parameters\":{\"lsaqifepdureeviv\":\"datanddlirqq\"}},\"parameters\":{\"tlfytbltytv\":{\"type\":\"SecureString\",\"defaultValue\":\"dataoklsuffpxesw\"},\"clmowurofo\":{\"type\":\"Array\",\"defaultValue\":\"datagcesfdd\"}},\"annotations\":[\"datacj\"],\"folder\":{\"name\":\"weob\"},\"\":{\"hixcc\":\"datadq\",\"og\":\"datakf\",\"bzd\":\"datayoxmyqzyqepg\",\"vo\":\"dataluokc\"}}")
+ "{\"type\":\"GoogleBigQueryV2Object\",\"typeProperties\":{\"table\":\"datancoqxtvytzq\",\"dataset\":\"dataldjvzmxy\"},\"description\":\"zz\",\"structure\":\"datajv\",\"schema\":\"datazbdbrlbo\",\"linkedServiceName\":{\"referenceName\":\"ltyo\",\"parameters\":{\"sokrlnrpeyl\":\"databibtkeiecupmwx\",\"dgiql\":\"dataiiul\"}},\"parameters\":{\"vunknsgvxhxr\":{\"type\":\"Object\",\"defaultValue\":\"dataw\"},\"yfjvifbmojtehq\":{\"type\":\"SecureString\",\"defaultValue\":\"datatrtc\"},\"mbhukdfpknvk\":{\"type\":\"Int\",\"defaultValue\":\"datatrcoufk\"}},\"annotations\":[\"datazje\"],\"folder\":{\"name\":\"meo\"},\"\":{\"knckkfxmuqeqkw\":\"datajl\",\"hdtezgfctu\":\"dataphfvsftsstwlpxca\"}}")
.toObject(GoogleBigQueryV2ObjectDataset.class);
- Assertions.assertEquals("qtr", model.description());
- Assertions.assertEquals("dcidpdaq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("tlfytbltytv").type());
- Assertions.assertEquals("weob", model.folder().name());
+ Assertions.assertEquals("zz", model.description());
+ Assertions.assertEquals("ltyo", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("vunknsgvxhxr").type());
+ Assertions.assertEquals("meo", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GoogleBigQueryV2ObjectDataset model
- = new GoogleBigQueryV2ObjectDataset().withDescription("qtr")
- .withStructure("datadoxdegacdedpkw")
- .withSchema("dataobp")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dcidpdaq")
- .withParameters(mapOf("lsaqifepdureeviv", "datanddlirqq")))
- .withParameters(mapOf("tlfytbltytv",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("dataoklsuffpxesw"),
- "clmowurofo",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datagcesfdd")))
- .withAnnotations(Arrays.asList("datacj"))
- .withFolder(new DatasetFolder().withName("weob"))
- .withTable("datamllznyjyuw")
- .withDataset("datazwgdpvhwiril");
+ GoogleBigQueryV2ObjectDataset model = new GoogleBigQueryV2ObjectDataset().withDescription("zz")
+ .withStructure("datajv")
+ .withSchema("datazbdbrlbo")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ltyo")
+ .withParameters(mapOf("sokrlnrpeyl", "databibtkeiecupmwx", "dgiql", "dataiiul")))
+ .withParameters(mapOf("vunknsgvxhxr",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataw"), "yfjvifbmojtehq",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datatrtc"),
+ "mbhukdfpknvk",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datatrcoufk")))
+ .withAnnotations(Arrays.asList("datazje"))
+ .withFolder(new DatasetFolder().withName("meo"))
+ .withTable("datancoqxtvytzq")
+ .withDataset("dataldjvzmxy");
model = BinaryData.fromObject(model).toObject(GoogleBigQueryV2ObjectDataset.class);
- Assertions.assertEquals("qtr", model.description());
- Assertions.assertEquals("dcidpdaq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("tlfytbltytv").type());
- Assertions.assertEquals("weob", model.folder().name());
+ Assertions.assertEquals("zz", model.description());
+ Assertions.assertEquals("ltyo", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("vunknsgvxhxr").type());
+ Assertions.assertEquals("meo", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2SourceTests.java
index 75c53bdd69c9..e20b582d39d0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleBigQueryV2SourceTests.java
@@ -11,19 +11,19 @@ public final class GoogleBigQueryV2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleBigQueryV2Source model = BinaryData.fromString(
- "{\"type\":\"GoogleBigQueryV2Source\",\"query\":\"dataanirlydsdmacydqa\",\"queryTimeout\":\"datayvwxubgulyz\",\"additionalColumns\":\"dataasxpprohuabdu\",\"sourceRetryCount\":\"datavsoxnpuapt\",\"sourceRetryWait\":\"datawekiqlscmtcljopi\",\"maxConcurrentConnections\":\"datawxvcfchokkcjjnq\",\"disableMetricsCollection\":\"datajoayaj\",\"\":{\"fbzbxeqzvokfrhfa\":\"datacxjmap\",\"uaxdulv\":\"dataxcgjuc\",\"mksgeqpai\":\"dataefsrxqscdbbwej\",\"eotvnet\":\"datalfscosf\"}}")
+ "{\"type\":\"GoogleBigQueryV2Source\",\"query\":\"dataqaptqyrnlyuyopww\",\"queryTimeout\":\"dataoubwbssvfzjjf\",\"additionalColumns\":\"dataxeosyl\",\"sourceRetryCount\":\"datappqjujbqrfw\",\"sourceRetryWait\":\"datawvpnbgyxo\",\"maxConcurrentConnections\":\"datakzeaiaycauvlfsc\",\"disableMetricsCollection\":\"dataqpzqivfgemvuicxw\",\"\":{\"atjm\":\"dataydlvfnucgwflj\"}}")
.toObject(GoogleBigQueryV2Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GoogleBigQueryV2Source model = new GoogleBigQueryV2Source().withSourceRetryCount("datavsoxnpuapt")
- .withSourceRetryWait("datawekiqlscmtcljopi")
- .withMaxConcurrentConnections("datawxvcfchokkcjjnq")
- .withDisableMetricsCollection("datajoayaj")
- .withQueryTimeout("datayvwxubgulyz")
- .withAdditionalColumns("dataasxpprohuabdu")
- .withQuery("dataanirlydsdmacydqa");
+ GoogleBigQueryV2Source model = new GoogleBigQueryV2Source().withSourceRetryCount("datappqjujbqrfw")
+ .withSourceRetryWait("datawvpnbgyxo")
+ .withMaxConcurrentConnections("datakzeaiaycauvlfsc")
+ .withDisableMetricsCollection("dataqpzqivfgemvuicxw")
+ .withQueryTimeout("dataoubwbssvfzjjf")
+ .withAdditionalColumns("dataxeosyl")
+ .withQuery("dataqaptqyrnlyuyopww");
model = BinaryData.fromObject(model).toObject(GoogleBigQueryV2Source.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleCloudStorageReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleCloudStorageReadSettingsTests.java
index 1f6702467ccc..97a76fded024 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleCloudStorageReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GoogleCloudStorageReadSettingsTests.java
@@ -11,25 +11,25 @@ public final class GoogleCloudStorageReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GoogleCloudStorageReadSettings model = BinaryData.fromString(
- "{\"type\":\"GoogleCloudStorageReadSettings\",\"recursive\":\"datannadn\",\"wildcardFolderPath\":\"datasbpxlserqgxnh\",\"wildcardFileName\":\"dataccd\",\"prefix\":\"dataxybn\",\"fileListPath\":\"datahmpmeglolpot\",\"enablePartitionDiscovery\":\"datamb\",\"partitionRootPath\":\"dataqjrytymfnojjh\",\"deleteFilesAfterCompletion\":\"datanthjqgovviv\",\"modifiedDatetimeStart\":\"dataxytrafettwytavp\",\"modifiedDatetimeEnd\":\"datalgyql\",\"maxConcurrentConnections\":\"datalgspy\",\"disableMetricsCollection\":\"dataapnhhvp\",\"\":{\"iyf\":\"dataourq\",\"fq\":\"datasegwez\"}}")
+ "{\"type\":\"GoogleCloudStorageReadSettings\",\"recursive\":\"datazfvxdkwvceqly\",\"wildcardFolderPath\":\"datayqqonkre\",\"wildcardFileName\":\"dataojusmdod\",\"prefix\":\"datak\",\"fileListPath\":\"datantaovlyyk\",\"enablePartitionDiscovery\":\"datafpkdsldyw\",\"partitionRootPath\":\"datavswlhj\",\"deleteFilesAfterCompletion\":\"datakqygszhpnatltj\",\"modifiedDatetimeStart\":\"dataqz\",\"modifiedDatetimeEnd\":\"datalkyrn\",\"maxConcurrentConnections\":\"datasbubzfayy\",\"disableMetricsCollection\":\"dataec\",\"\":{\"vsmvvfpkym\":\"datarederzsnfgmohhcg\",\"wghfg\":\"datanvvwfaorulboawzp\"}}")
.toObject(GoogleCloudStorageReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
GoogleCloudStorageReadSettings model
- = new GoogleCloudStorageReadSettings().withMaxConcurrentConnections("datalgspy")
- .withDisableMetricsCollection("dataapnhhvp")
- .withRecursive("datannadn")
- .withWildcardFolderPath("datasbpxlserqgxnh")
- .withWildcardFileName("dataccd")
- .withPrefix("dataxybn")
- .withFileListPath("datahmpmeglolpot")
- .withEnablePartitionDiscovery("datamb")
- .withPartitionRootPath("dataqjrytymfnojjh")
- .withDeleteFilesAfterCompletion("datanthjqgovviv")
- .withModifiedDatetimeStart("dataxytrafettwytavp")
- .withModifiedDatetimeEnd("datalgyql");
+ = new GoogleCloudStorageReadSettings().withMaxConcurrentConnections("datasbubzfayy")
+ .withDisableMetricsCollection("dataec")
+ .withRecursive("datazfvxdkwvceqly")
+ .withWildcardFolderPath("datayqqonkre")
+ .withWildcardFileName("dataojusmdod")
+ .withPrefix("datak")
+ .withFileListPath("datantaovlyyk")
+ .withEnablePartitionDiscovery("datafpkdsldyw")
+ .withPartitionRootPath("datavswlhj")
+ .withDeleteFilesAfterCompletion("datakqygszhpnatltj")
+ .withModifiedDatetimeStart("dataqz")
+ .withModifiedDatetimeEnd("datalkyrn");
model = BinaryData.fromObject(model).toObject(GoogleCloudStorageReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumDatasetTypePropertiesTests.java
index 36c87ae8a180..bd0a57eaed4a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumDatasetTypePropertiesTests.java
@@ -10,16 +10,17 @@
public final class GreenplumDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- GreenplumDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datab\",\"table\":\"datau\",\"schema\":\"datagtxlzncoqxtvytzq\"}")
- .toObject(GreenplumDatasetTypeProperties.class);
+ GreenplumDatasetTypeProperties model = BinaryData
+ .fromString(
+ "{\"tableName\":\"datamqeumzyyhmgqa\",\"table\":\"datavjqutxrbgbzgfhzd\",\"schema\":\"datahk\"}")
+ .toObject(GreenplumDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GreenplumDatasetTypeProperties model = new GreenplumDatasetTypeProperties().withTableName("datab")
- .withTable("datau")
- .withSchema("datagtxlzncoqxtvytzq");
+ GreenplumDatasetTypeProperties model = new GreenplumDatasetTypeProperties().withTableName("datamqeumzyyhmgqa")
+ .withTable("datavjqutxrbgbzgfhzd")
+ .withSchema("datahk");
model = BinaryData.fromObject(model).toObject(GreenplumDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumSourceTests.java
index 8f0742c19631..30611e058d05 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumSourceTests.java
@@ -11,19 +11,19 @@ public final class GreenplumSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GreenplumSource model = BinaryData.fromString(
- "{\"type\":\"GreenplumSource\",\"query\":\"datahndfpf\",\"queryTimeout\":\"datafdgf\",\"additionalColumns\":\"dataoeh\",\"sourceRetryCount\":\"datapkssjbw\",\"sourceRetryWait\":\"dataxdgcfcfky\",\"maxConcurrentConnections\":\"datajwxhslrbwwk\",\"disableMetricsCollection\":\"datawodhsodofsxjiky\",\"\":{\"cxdmxhuwldfa\":\"datauhuixqwogg\",\"dkbgsg\":\"datakyft\",\"ayqkg\":\"datapyckmncrutoudjm\"}}")
+ "{\"type\":\"GreenplumSource\",\"query\":\"databrcdumkqhatckom\",\"queryTimeout\":\"datafjs\",\"additionalColumns\":\"datavzvkddaeiepvjr\",\"sourceRetryCount\":\"dataksx\",\"sourceRetryWait\":\"datakb\",\"maxConcurrentConnections\":\"datauawokrhhj\",\"disableMetricsCollection\":\"datahrmuwvs\",\"\":{\"imgg\":\"datauosidtxmbnm\"}}")
.toObject(GreenplumSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GreenplumSource model = new GreenplumSource().withSourceRetryCount("datapkssjbw")
- .withSourceRetryWait("dataxdgcfcfky")
- .withMaxConcurrentConnections("datajwxhslrbwwk")
- .withDisableMetricsCollection("datawodhsodofsxjiky")
- .withQueryTimeout("datafdgf")
- .withAdditionalColumns("dataoeh")
- .withQuery("datahndfpf");
+ GreenplumSource model = new GreenplumSource().withSourceRetryCount("dataksx")
+ .withSourceRetryWait("datakb")
+ .withMaxConcurrentConnections("datauawokrhhj")
+ .withDisableMetricsCollection("datahrmuwvs")
+ .withQueryTimeout("datafjs")
+ .withAdditionalColumns("datavzvkddaeiepvjr")
+ .withQuery("databrcdumkqhatckom");
model = BinaryData.fromObject(model).toObject(GreenplumSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumTableDatasetTests.java
index 3ddf5eb2cb8a..19074a2bda67 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/GreenplumTableDatasetTests.java
@@ -19,37 +19,38 @@ public final class GreenplumTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
GreenplumTableDataset model = BinaryData.fromString(
- "{\"type\":\"GreenplumTable\",\"typeProperties\":{\"tableName\":\"dataeisvvvgyp\",\"table\":\"dataeovej\",\"schema\":\"dataaleczt\"},\"description\":\"h\",\"structure\":\"datazpuvfs\",\"schema\":\"datagrqefnq\",\"linkedServiceName\":{\"referenceName\":\"oll\",\"parameters\":{\"qieh\":\"datarmuzemb\",\"wnaxoxl\":\"datahjofy\",\"slqcxuthv\":\"datarx\"}},\"parameters\":{\"yju\":{\"type\":\"SecureString\",\"defaultValue\":\"datayhrgmabspmlu\"},\"rbfgqi\":{\"type\":\"Object\",\"defaultValue\":\"datadputo\"},\"r\":{\"type\":\"Bool\",\"defaultValue\":\"datargcuzjmvkr\"},\"ybqjvfio\":{\"type\":\"SecureString\",\"defaultValue\":\"datahgcmljzksqi\"}},\"annotations\":[\"dataaqpvhszopeuku\",\"datadswbsskgq\",\"dataemosq\",\"datafsjbpwjwz\"],\"folder\":{\"name\":\"pdzy\"},\"\":{\"udqhad\":\"datahxfpzc\",\"vl\":\"dataj\"}}")
+ "{\"type\":\"GreenplumTable\",\"typeProperties\":{\"tableName\":\"dataypngocbd\",\"table\":\"datarivptbczsu\",\"schema\":\"datarzukekytkzvtv\"},\"description\":\"atvogpycein\",\"structure\":\"datarhbd\",\"schema\":\"databyp\",\"linkedServiceName\":{\"referenceName\":\"s\",\"parameters\":{\"bqpsezsggd\":\"datafjuda\"}},\"parameters\":{\"fzrguzliyv\":{\"type\":\"String\",\"defaultValue\":\"databrtsrdplqdyzacia\"},\"djuljgxotuda\":{\"type\":\"SecureString\",\"defaultValue\":\"datasinva\"},\"ifgs\":{\"type\":\"Bool\",\"defaultValue\":\"datayaosthulzu\"},\"cygimizl\":{\"type\":\"Int\",\"defaultValue\":\"datadlnoc\"}},\"annotations\":[\"databwmgksrlmspp\",\"dataoeszthjtryjsk\",\"dataiylgzzu\",\"dataixpsybqowgvmxw\"],\"folder\":{\"name\":\"xdhkoex\"},\"\":{\"wscmneev\":\"datagnaka\"}}")
.toObject(GreenplumTableDataset.class);
- Assertions.assertEquals("h", model.description());
- Assertions.assertEquals("oll", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("yju").type());
- Assertions.assertEquals("pdzy", model.folder().name());
+ Assertions.assertEquals("atvogpycein", model.description());
+ Assertions.assertEquals("s", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("fzrguzliyv").type());
+ Assertions.assertEquals("xdhkoex", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- GreenplumTableDataset model = new GreenplumTableDataset().withDescription("h")
- .withStructure("datazpuvfs")
- .withSchema("datagrqefnq")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("oll")
- .withParameters(mapOf("qieh", "datarmuzemb", "wnaxoxl", "datahjofy", "slqcxuthv", "datarx")))
- .withParameters(mapOf("yju",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datayhrgmabspmlu"),
- "rbfgqi", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datadputo"),
- "r", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datargcuzjmvkr"),
- "ybqjvfio",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datahgcmljzksqi")))
- .withAnnotations(Arrays.asList("dataaqpvhszopeuku", "datadswbsskgq", "dataemosq", "datafsjbpwjwz"))
- .withFolder(new DatasetFolder().withName("pdzy"))
- .withTableName("dataeisvvvgyp")
- .withTable("dataeovej")
- .withSchemaTypePropertiesSchema("dataaleczt");
+ GreenplumTableDataset model = new GreenplumTableDataset().withDescription("atvogpycein")
+ .withStructure("datarhbd")
+ .withSchema("databyp")
+ .withLinkedServiceName(
+ new LinkedServiceReference().withReferenceName("s").withParameters(mapOf("bqpsezsggd", "datafjuda")))
+ .withParameters(mapOf("fzrguzliyv",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("databrtsrdplqdyzacia"),
+ "djuljgxotuda",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datasinva"),
+ "ifgs", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datayaosthulzu"),
+ "cygimizl", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datadlnoc")))
+ .withAnnotations(
+ Arrays.asList("databwmgksrlmspp", "dataoeszthjtryjsk", "dataiylgzzu", "dataixpsybqowgvmxw"))
+ .withFolder(new DatasetFolder().withName("xdhkoex"))
+ .withTableName("dataypngocbd")
+ .withTable("datarivptbczsu")
+ .withSchemaTypePropertiesSchema("datarzukekytkzvtv");
model = BinaryData.fromObject(model).toObject(GreenplumTableDataset.class);
- Assertions.assertEquals("h", model.description());
- Assertions.assertEquals("oll", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("yju").type());
- Assertions.assertEquals("pdzy", model.folder().name());
+ Assertions.assertEquals("atvogpycein", model.description());
+ Assertions.assertEquals("s", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("fzrguzliyv").type());
+ Assertions.assertEquals("xdhkoex", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseObjectDatasetTests.java
index dda15212888b..53cd9c23a81c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseObjectDatasetTests.java
@@ -19,35 +19,37 @@ public final class HBaseObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HBaseObjectDataset model = BinaryData.fromString(
- "{\"type\":\"HBaseObject\",\"typeProperties\":{\"tableName\":\"datadjvzmxyrazzstjvc\"},\"description\":\"bdbrl\",\"structure\":\"datazlty\",\"schema\":\"dataacbibtk\",\"linkedServiceName\":{\"referenceName\":\"iecup\",\"parameters\":{\"krlnrpeylfiiul\":\"datads\",\"hcxwwwvun\":\"datadgiql\",\"atrtcqyfjvifbmo\":\"datansgvxhxrm\",\"bhukdfpknv\":\"datatehqyoytrcoufkq\"}},\"parameters\":{\"hzjlrknckkfxm\":{\"type\":\"Float\",\"defaultValue\":\"datajezchmeo\"},\"fts\":{\"type\":\"Float\",\"defaultValue\":\"dataqkwqphfv\"},\"zgfctuuzow\":{\"type\":\"Bool\",\"defaultValue\":\"datalpxcachdt\"}},\"annotations\":[\"datavuxnx\",\"datauohshzultdbvm\"],\"folder\":{\"name\":\"ypngocbd\"},\"\":{\"zsuzgrzu\":\"dataivptb\",\"aatvogpyceinha\":\"dataekytkzvtv\",\"khwfjudapbq\":\"datahbdxsbypl\"}}")
+ "{\"type\":\"HBaseObject\",\"typeProperties\":{\"tableName\":\"datacbicfecthotb\"},\"description\":\"whz\",\"structure\":\"dataxjvtwkyjdpayxo\",\"schema\":\"dataiwuzrgqztjfkgbtq\",\"linkedServiceName\":{\"referenceName\":\"jobsynn\",\"parameters\":{\"wfudmpf\":\"dataonjqhdheosx\"}},\"parameters\":{\"bb\":{\"type\":\"Array\",\"defaultValue\":\"datahtjtntcwgp\"},\"spkvrmp\":{\"type\":\"Array\",\"defaultValue\":\"dataecctokfspvjr\"},\"djmvphwfnu\":{\"type\":\"String\",\"defaultValue\":\"datayptwjwiyyeohgmc\"},\"ueprpmofxnwc\":{\"type\":\"SecureString\",\"defaultValue\":\"datavfzzioxbgom\"}},\"annotations\":[\"dataoxi\",\"datatxxxajse\",\"datab\",\"datannrnkyj\"],\"folder\":{\"name\":\"pcbs\"},\"\":{\"pkjealkdbewhotv\":\"dataehczbnivcohsxv\",\"dktrjtoqszh\":\"datamyzuqfd\"}}")
.toObject(HBaseObjectDataset.class);
- Assertions.assertEquals("bdbrl", model.description());
- Assertions.assertEquals("iecup", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("hzjlrknckkfxm").type());
- Assertions.assertEquals("ypngocbd", model.folder().name());
+ Assertions.assertEquals("whz", model.description());
+ Assertions.assertEquals("jobsynn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("bb").type());
+ Assertions.assertEquals("pcbs", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HBaseObjectDataset model = new HBaseObjectDataset().withDescription("bdbrl")
- .withStructure("datazlty")
- .withSchema("dataacbibtk")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("iecup")
- .withParameters(mapOf("krlnrpeylfiiul", "datads", "hcxwwwvun", "datadgiql", "atrtcqyfjvifbmo",
- "datansgvxhxrm", "bhukdfpknv", "datatehqyoytrcoufkq")))
- .withParameters(mapOf("hzjlrknckkfxm",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datajezchmeo"), "fts",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqkwqphfv"),
- "zgfctuuzow",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datalpxcachdt")))
- .withAnnotations(Arrays.asList("datavuxnx", "datauohshzultdbvm"))
- .withFolder(new DatasetFolder().withName("ypngocbd"))
- .withTableName("datadjvzmxyrazzstjvc");
+ HBaseObjectDataset model = new HBaseObjectDataset().withDescription("whz")
+ .withStructure("dataxjvtwkyjdpayxo")
+ .withSchema("dataiwuzrgqztjfkgbtq")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("jobsynn")
+ .withParameters(mapOf("wfudmpf", "dataonjqhdheosx")))
+ .withParameters(mapOf("bb",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datahtjtntcwgp"),
+ "spkvrmp",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataecctokfspvjr"),
+ "djmvphwfnu",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datayptwjwiyyeohgmc"),
+ "ueprpmofxnwc",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datavfzzioxbgom")))
+ .withAnnotations(Arrays.asList("dataoxi", "datatxxxajse", "datab", "datannrnkyj"))
+ .withFolder(new DatasetFolder().withName("pcbs"))
+ .withTableName("datacbicfecthotb");
model = BinaryData.fromObject(model).toObject(HBaseObjectDataset.class);
- Assertions.assertEquals("bdbrl", model.description());
- Assertions.assertEquals("iecup", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("hzjlrknckkfxm").type());
- Assertions.assertEquals("ypngocbd", model.folder().name());
+ Assertions.assertEquals("whz", model.description());
+ Assertions.assertEquals("jobsynn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("bb").type());
+ Assertions.assertEquals("pcbs", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseSourceTests.java
index 83eee9df2e66..ce004c092703 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HBaseSourceTests.java
@@ -11,19 +11,19 @@ public final class HBaseSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HBaseSource model = BinaryData.fromString(
- "{\"type\":\"HBaseSource\",\"query\":\"datafn\",\"queryTimeout\":\"dataeyavldovpwrq\",\"additionalColumns\":\"datazokplzliizb\",\"sourceRetryCount\":\"datajumulhfq\",\"sourceRetryWait\":\"datanchah\",\"maxConcurrentConnections\":\"datanrptrqcap\",\"disableMetricsCollection\":\"datafvowzbk\",\"\":{\"qzzkplqmca\":\"datapzdpujywjmo\",\"jgfpqwwugfwpvj\":\"dataseiauveeng\"}}")
+ "{\"type\":\"HBaseSource\",\"query\":\"dataqgpldrn\",\"queryTimeout\":\"datahdb\",\"additionalColumns\":\"databmsbetzufkvx\",\"sourceRetryCount\":\"databddrtngdc\",\"sourceRetryWait\":\"datajzgzaeuu\",\"maxConcurrentConnections\":\"datavheqzl\",\"disableMetricsCollection\":\"datavaskrgoodfhpyue\",\"\":{\"lizlzxh\":\"datanyddp\",\"sjwawl\":\"datacuglgmfznholaf\",\"yk\":\"dataqmznkcwiok\"}}")
.toObject(HBaseSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HBaseSource model = new HBaseSource().withSourceRetryCount("datajumulhfq")
- .withSourceRetryWait("datanchah")
- .withMaxConcurrentConnections("datanrptrqcap")
- .withDisableMetricsCollection("datafvowzbk")
- .withQueryTimeout("dataeyavldovpwrq")
- .withAdditionalColumns("datazokplzliizb")
- .withQuery("datafn");
+ HBaseSource model = new HBaseSource().withSourceRetryCount("databddrtngdc")
+ .withSourceRetryWait("datajzgzaeuu")
+ .withMaxConcurrentConnections("datavheqzl")
+ .withDisableMetricsCollection("datavaskrgoodfhpyue")
+ .withQueryTimeout("datahdb")
+ .withAdditionalColumns("databmsbetzufkvx")
+ .withQuery("dataqgpldrn");
model = BinaryData.fromObject(model).toObject(HBaseSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTests.java
index afbac2ddef50..358f82f341d7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTests.java
@@ -23,71 +23,83 @@ public final class HDInsightHiveActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightHiveActivity model = BinaryData.fromString(
- "{\"type\":\"HDInsightHive\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"cndbu\",\"parameters\":{\"tnbk\":\"datakoxwyxodpcgdv\"}}],\"arguments\":[\"dataafila\",\"datazcdugnzymljg\",\"dataykaqwnkxoqe\",\"datajznuqgl\"],\"getDebugInfo\":\"Always\",\"scriptPath\":\"dataewshhqgjvchl\",\"scriptLinkedService\":{\"referenceName\":\"zfbtczzjf\",\"parameters\":{\"u\":\"datavwizjraksahwq\",\"misnb\":\"dataltfknro\",\"fvqtvukcfesizkn\":\"datacz\"}},\"defines\":{\"hwysdmovbvn\":\"dataxflzhgr\",\"czoln\":\"datayqqofdgzly\",\"gg\":\"dataw\",\"zjmukfwmhzarrft\":\"datatyvoxnjbyjgo\"},\"variables\":{\"vvab\":\"dataifrjgvhone\"},\"queryTimeout\":1200530863},\"linkedServiceName\":{\"referenceName\":\"fvsolkjowvzyoe\",\"parameters\":{\"r\":\"datatlyguothnucqktua\"}},\"policy\":{\"timeout\":\"datapriict\",\"retry\":\"datadlbahmivtuphwwy\",\"retryIntervalInSeconds\":3434022,\"secureInput\":false,\"secureOutput\":false,\"\":{\"pxgjmyoufqa\":\"dataomnrziwk\",\"vtrtxggm\":\"datauaypcdikkmyr\",\"gjukntknjhywgzi\":\"dataohuvasxjzklq\"}},\"name\":\"cwnefdehptlnw\",\"description\":\"a\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"x\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Failed\"],\"\":{\"cbdsuwctv\":\"datahtikfiwpgxya\"}}],\"userProperties\":[{\"name\":\"jfg\",\"value\":\"datatl\"}],\"\":{\"zrzi\":\"dataeyhpbt\",\"y\":\"datahkkdcjymdoldb\"}}")
+ "{\"type\":\"HDInsightHive\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"ghloemqapvn\",\"parameters\":{\"bqadtv\":\"dataqkrsnxuezw\"}},{\"referenceName\":\"gug\",\"parameters\":{\"xxe\":\"datagkriv\",\"odvzjkz\":\"dataplphkiyiqpi\"}},{\"referenceName\":\"lvxdpopubbwps\",\"parameters\":{\"w\":\"datab\",\"mmgf\":\"datahjqakacbcbrsnnv\",\"qmty\":\"datat\",\"jkbisjurilqc\":\"dataqut\"}}],\"arguments\":[\"datadorbufog\",\"datackbizqqajs\"],\"getDebugInfo\":\"Always\",\"scriptPath\":\"dataojgv\",\"scriptLinkedService\":{\"referenceName\":\"zvtgwlzqcyvrbg\",\"parameters\":{\"zzcbc\":\"datardekjbljfkqubnn\"}},\"defines\":{\"lwfd\":\"datan\",\"bwjtnfaumqkgccld\":\"dataxxaoyiskyoasxakb\"},\"variables\":{\"zwsnryfaprhfc\":\"dataeweeeg\"},\"queryTimeout\":124430894},\"linkedServiceName\":{\"referenceName\":\"r\",\"parameters\":{\"nfrhbkn\":\"datadszuxhaqlywty\",\"xhfg\":\"dataagpnmcqud\"}},\"policy\":{\"timeout\":\"dataegm\",\"retry\":\"dataebzoujhijlduuvxk\",\"retryIntervalInSeconds\":1813397068,\"secureInput\":false,\"secureOutput\":true,\"\":{\"exgnfjwfo\":\"datadzwbsk\",\"pmowlsrxytev\":\"datazlia\",\"nzzhyl\":\"dataqxpmfhehtrpql\",\"m\":\"datazuxqqrmck\"}},\"name\":\"sueutby\",\"description\":\"zg\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"jpiecnrivsiwws\",\"dependencyConditions\":[\"Failed\",\"Skipped\"],\"\":{\"mjtanrirrnqloom\":\"dataikouvpcjyhsz\",\"dvknqui\":\"dataywyqgaskap\"}},{\"activity\":\"ipgvfchzcpv\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Skipped\"],\"\":{\"bfpte\":\"datazpfgkslvbrxlsbg\"}}],\"userProperties\":[{\"name\":\"neopxdbhcfswpdar\",\"value\":\"datacabsmrfx\"}],\"\":{\"seexdboatvsfyxdf\":\"datavzgwvmhbiziij\",\"gfxacojca\":\"dataqrnawnqy\",\"j\":\"dataaxor\",\"dtnaptwmawypk\":\"dataoyngxogqvwchyn\"}}")
.toObject(HDInsightHiveActivity.class);
- Assertions.assertEquals("cwnefdehptlnw", model.name());
- Assertions.assertEquals("a", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("x", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jfg", model.userProperties().get(0).name());
- Assertions.assertEquals("fvsolkjowvzyoe", model.linkedServiceName().referenceName());
- Assertions.assertEquals(3434022, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("sueutby", model.name());
+ Assertions.assertEquals("zg", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("jpiecnrivsiwws", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("neopxdbhcfswpdar", model.userProperties().get(0).name());
+ Assertions.assertEquals("r", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1813397068, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("cndbu", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("ghloemqapvn", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("zfbtczzjf", model.scriptLinkedService().referenceName());
- Assertions.assertEquals(1200530863, model.queryTimeout());
+ Assertions.assertEquals("zvtgwlzqcyvrbg", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals(124430894, model.queryTimeout());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HDInsightHiveActivity model = new HDInsightHiveActivity().withName("cwnefdehptlnw")
- .withDescription("a")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("x")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("jfg").withValue("datatl")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("fvsolkjowvzyoe")
- .withParameters(mapOf("r", "datatlyguothnucqktua")))
- .withPolicy(new ActivityPolicy().withTimeout("datapriict")
- .withRetry("datadlbahmivtuphwwy")
- .withRetryIntervalInSeconds(3434022)
- .withSecureInput(false)
- .withSecureOutput(false)
- .withAdditionalProperties(mapOf()))
- .withStorageLinkedServices(Arrays.asList(new LinkedServiceReference().withReferenceName("cndbu")
- .withParameters(mapOf("tnbk", "datakoxwyxodpcgdv"))))
- .withArguments(Arrays.asList("dataafila", "datazcdugnzymljg", "dataykaqwnkxoqe", "datajznuqgl"))
- .withGetDebugInfo(HDInsightActivityDebugInfoOption.ALWAYS)
- .withScriptPath("dataewshhqgjvchl")
- .withScriptLinkedService(new LinkedServiceReference().withReferenceName("zfbtczzjf")
- .withParameters(mapOf("u", "datavwizjraksahwq", "misnb", "dataltfknro", "fvqtvukcfesizkn", "datacz")))
- .withDefines(mapOf("hwysdmovbvn", "dataxflzhgr", "czoln", "datayqqofdgzly", "gg", "dataw",
- "zjmukfwmhzarrft", "datatyvoxnjbyjgo"))
- .withVariables(mapOf("vvab", "dataifrjgvhone"))
- .withQueryTimeout(1200530863);
+ HDInsightHiveActivity model
+ = new HDInsightHiveActivity().withName("sueutby")
+ .withDescription("zg")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("jpiecnrivsiwws")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ipgvfchzcpv")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("neopxdbhcfswpdar").withValue("datacabsmrfx")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("r")
+ .withParameters(mapOf("nfrhbkn", "datadszuxhaqlywty", "xhfg", "dataagpnmcqud")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataegm")
+ .withRetry("dataebzoujhijlduuvxk")
+ .withRetryIntervalInSeconds(1813397068)
+ .withSecureInput(false)
+ .withSecureOutput(true)
+ .withAdditionalProperties(mapOf()))
+ .withStorageLinkedServices(Arrays.asList(
+ new LinkedServiceReference().withReferenceName("ghloemqapvn")
+ .withParameters(mapOf("bqadtv", "dataqkrsnxuezw")),
+ new LinkedServiceReference().withReferenceName("gug")
+ .withParameters(mapOf("xxe", "datagkriv", "odvzjkz", "dataplphkiyiqpi")),
+ new LinkedServiceReference().withReferenceName("lvxdpopubbwps")
+ .withParameters(mapOf("w", "datab", "mmgf", "datahjqakacbcbrsnnv", "qmty", "datat",
+ "jkbisjurilqc", "dataqut"))))
+ .withArguments(Arrays.asList("datadorbufog", "datackbizqqajs"))
+ .withGetDebugInfo(HDInsightActivityDebugInfoOption.ALWAYS)
+ .withScriptPath("dataojgv")
+ .withScriptLinkedService(new LinkedServiceReference().withReferenceName("zvtgwlzqcyvrbg")
+ .withParameters(mapOf("zzcbc", "datardekjbljfkqubnn")))
+ .withDefines(mapOf("lwfd", "datan", "bwjtnfaumqkgccld", "dataxxaoyiskyoasxakb"))
+ .withVariables(mapOf("zwsnryfaprhfc", "dataeweeeg"))
+ .withQueryTimeout(124430894);
model = BinaryData.fromObject(model).toObject(HDInsightHiveActivity.class);
- Assertions.assertEquals("cwnefdehptlnw", model.name());
- Assertions.assertEquals("a", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("x", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jfg", model.userProperties().get(0).name());
- Assertions.assertEquals("fvsolkjowvzyoe", model.linkedServiceName().referenceName());
- Assertions.assertEquals(3434022, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("sueutby", model.name());
+ Assertions.assertEquals("zg", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("jpiecnrivsiwws", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("neopxdbhcfswpdar", model.userProperties().get(0).name());
+ Assertions.assertEquals("r", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1813397068, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("cndbu", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("ghloemqapvn", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("zfbtczzjf", model.scriptLinkedService().referenceName());
- Assertions.assertEquals(1200530863, model.queryTimeout());
+ Assertions.assertEquals("zvtgwlzqcyvrbg", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals(124430894, model.queryTimeout());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTypePropertiesTests.java
index c894b96cd517..c2f7b3faf4ca 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightHiveActivityTypePropertiesTests.java
@@ -17,37 +17,41 @@ public final class HDInsightHiveActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightHiveActivityTypeProperties model = BinaryData.fromString(
- "{\"storageLinkedServices\":[{\"referenceName\":\"ephviuexf\",\"parameters\":{\"axru\":\"datadoxhyiya\",\"xynkh\":\"datafkmti\"}},{\"referenceName\":\"p\",\"parameters\":{\"rnhpmsdgmx\":\"datahzdbbitp\",\"yevhnqtb\":\"datafodvzpxmojxbvgie\",\"xmqudnqcbbbhin\":\"datasvjodgplagwvgb\"}}],\"arguments\":[\"datasz\",\"databfzkvrmdoshi\",\"datayzqdnrgnyb\"],\"getDebugInfo\":\"Always\",\"scriptPath\":\"datajbmkhxunqrvqt\",\"scriptLinkedService\":{\"referenceName\":\"g\",\"parameters\":{\"u\":\"datapmcl\",\"dcqrssqwzndzuxlg\":\"datadabh\"}},\"defines\":{\"bzablmpntj\":\"datangyqlzozmbapj\",\"wlvsefvkxxd\":\"datazkymcgtbpbfbgfwj\",\"zm\":\"datagbnqmhr\",\"lqrkstjdjdasomxw\":\"dataxwgrflqbugxudsmd\"},\"variables\":{\"lsjf\":\"datayl\",\"qdjxurbjx\":\"dataczwikglmcgyzz\",\"guzv\":\"dataarx\"},\"queryTimeout\":841829397}")
+ "{\"storageLinkedServices\":[{\"referenceName\":\"idoqvcjspjpmt\",\"parameters\":{\"cgzvqpnjqpwx\":\"datavizaygtbmluy\",\"pa\":\"datakui\",\"dleegwlhanyueizh\":\"datavlnzwicqopwm\"}},{\"referenceName\":\"djkmxbghxiotlfzb\",\"parameters\":{\"dicoaysar\":\"datauqkb\"}},{\"referenceName\":\"qkgausc\",\"parameters\":{\"fejdgojavqezek\":\"datayfyjeexmlkx\",\"s\":\"datavayyyowjpsmnxcc\"}},{\"referenceName\":\"hlokhmkqy\",\"parameters\":{\"lmwzkxaglwd\":\"dataddwfhfjfato\",\"hvioccszdaxafu\":\"datatjfnmxzu\"}}],\"arguments\":[\"datanqfwobnbluutm\",\"dataimlozlfdxjirfye\"],\"getDebugInfo\":\"None\",\"scriptPath\":\"datadc\",\"scriptLinkedService\":{\"referenceName\":\"ormxipwcqha\",\"parameters\":{\"wiocuhas\":\"datafnfa\",\"whotjcgdpqk\":\"dataielhtukhei\"}},\"defines\":{\"vrglqlvmkeseyqo\":\"dataqm\",\"hmzlet\":\"datamjuqq\",\"uefjbmowqwodm\":\"datackjuwkkvarff\",\"ciapvcsw\":\"datardtywajqwa\"},\"variables\":{\"tftaqmrimletjvz\":\"datapcpgc\",\"wgszxupwriz\":\"datatfgabiblhzfglp\"},\"queryTimeout\":948481905}")
.toObject(HDInsightHiveActivityTypeProperties.class);
- Assertions.assertEquals("ephviuexf", model.storageLinkedServices().get(0).referenceName());
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("g", model.scriptLinkedService().referenceName());
- Assertions.assertEquals(841829397, model.queryTimeout());
+ Assertions.assertEquals("idoqvcjspjpmt", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.NONE, model.getDebugInfo());
+ Assertions.assertEquals("ormxipwcqha", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals(948481905, model.queryTimeout());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
HDInsightHiveActivityTypeProperties model = new HDInsightHiveActivityTypeProperties()
.withStorageLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("ephviuexf")
- .withParameters(mapOf("axru", "datadoxhyiya", "xynkh", "datafkmti")),
- new LinkedServiceReference().withReferenceName("p")
- .withParameters(mapOf("rnhpmsdgmx", "datahzdbbitp", "yevhnqtb", "datafodvzpxmojxbvgie",
- "xmqudnqcbbbhin", "datasvjodgplagwvgb"))))
- .withArguments(Arrays.asList("datasz", "databfzkvrmdoshi", "datayzqdnrgnyb"))
- .withGetDebugInfo(HDInsightActivityDebugInfoOption.ALWAYS)
- .withScriptPath("datajbmkhxunqrvqt")
- .withScriptLinkedService(new LinkedServiceReference().withReferenceName("g")
- .withParameters(mapOf("u", "datapmcl", "dcqrssqwzndzuxlg", "datadabh")))
- .withDefines(mapOf("bzablmpntj", "datangyqlzozmbapj", "wlvsefvkxxd", "datazkymcgtbpbfbgfwj", "zm",
- "datagbnqmhr", "lqrkstjdjdasomxw", "dataxwgrflqbugxudsmd"))
- .withVariables(mapOf("lsjf", "datayl", "qdjxurbjx", "dataczwikglmcgyzz", "guzv", "dataarx"))
- .withQueryTimeout(841829397);
+ new LinkedServiceReference().withReferenceName("idoqvcjspjpmt")
+ .withParameters(mapOf("cgzvqpnjqpwx", "datavizaygtbmluy", "pa", "datakui", "dleegwlhanyueizh",
+ "datavlnzwicqopwm")),
+ new LinkedServiceReference().withReferenceName("djkmxbghxiotlfzb")
+ .withParameters(mapOf("dicoaysar", "datauqkb")),
+ new LinkedServiceReference().withReferenceName("qkgausc")
+ .withParameters(mapOf("fejdgojavqezek", "datayfyjeexmlkx", "s", "datavayyyowjpsmnxcc")),
+ new LinkedServiceReference().withReferenceName("hlokhmkqy")
+ .withParameters(mapOf("lmwzkxaglwd", "dataddwfhfjfato", "hvioccszdaxafu", "datatjfnmxzu"))))
+ .withArguments(Arrays.asList("datanqfwobnbluutm", "dataimlozlfdxjirfye"))
+ .withGetDebugInfo(HDInsightActivityDebugInfoOption.NONE)
+ .withScriptPath("datadc")
+ .withScriptLinkedService(new LinkedServiceReference().withReferenceName("ormxipwcqha")
+ .withParameters(mapOf("wiocuhas", "datafnfa", "whotjcgdpqk", "dataielhtukhei")))
+ .withDefines(mapOf("vrglqlvmkeseyqo", "dataqm", "hmzlet", "datamjuqq", "uefjbmowqwodm", "datackjuwkkvarff",
+ "ciapvcsw", "datardtywajqwa"))
+ .withVariables(mapOf("tftaqmrimletjvz", "datapcpgc", "wgszxupwriz", "datatfgabiblhzfglp"))
+ .withQueryTimeout(948481905);
model = BinaryData.fromObject(model).toObject(HDInsightHiveActivityTypeProperties.class);
- Assertions.assertEquals("ephviuexf", model.storageLinkedServices().get(0).referenceName());
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("g", model.scriptLinkedService().referenceName());
- Assertions.assertEquals(841829397, model.queryTimeout());
+ Assertions.assertEquals("idoqvcjspjpmt", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.NONE, model.getDebugInfo());
+ Assertions.assertEquals("ormxipwcqha", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals(948481905, model.queryTimeout());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTests.java
index 9be2343c578a..07ab67b6a5da 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTests.java
@@ -23,86 +23,78 @@ public final class HDInsightMapReduceActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightMapReduceActivity model = BinaryData.fromString(
- "{\"type\":\"HDInsightMapReduce\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"elht\",\"parameters\":{\"cgdpqkfxdqmdvrgl\":\"dataeimwhot\",\"tmjuq\":\"datalvmkeseyq\",\"juwkkvarffjuefj\":\"dataahmzletac\",\"odmdrdtywa\":\"datamowq\"}},{\"referenceName\":\"qwa\",\"parameters\":{\"taqmrimletj\":\"dataapvcswzjrpcpgclt\"}},{\"referenceName\":\"zptfgabi\",\"parameters\":{\"wgszxupwriz\":\"datazfglp\",\"sjpq\":\"dataqnbiiand\"}}],\"arguments\":[\"dataku\",\"dataosltch\",\"datauhvdrfh\"],\"getDebugInfo\":\"Always\",\"className\":\"dataxhnojfdiijch\",\"jarFilePath\":\"dataaaabtxrhemnkyk\",\"jarLinkedService\":{\"referenceName\":\"uomwyoktzffpcd\",\"parameters\":{\"eqvkuvy\":\"datapz\",\"rfok\":\"datai\",\"bdh\":\"datalcoikstap\"}},\"jarLibs\":[\"dataugkugwtg\",\"dataktwayha\",\"datahqvxeyl\"],\"defines\":{\"cufzxxqd\":\"dataatbsghtk\",\"vqvernqk\":\"datatv\"}},\"linkedServiceName\":{\"referenceName\":\"yyysvtjoxw\",\"parameters\":{\"dwoevmocnfzmu\":\"datazwoczfizfcmpddz\",\"luwuns\":\"dataykxlfl\",\"mgpomcre\":\"datayqpmnyvn\",\"lilzv\":\"datataz\"}},\"policy\":{\"timeout\":\"datadnobxcdx\",\"retry\":\"dataraeodixofl\",\"retryIntervalInSeconds\":1228339310,\"secureInput\":false,\"secureOutput\":false,\"\":{\"rrwbcycwasmrfbw\":\"datacozfjsfrbjrbqc\",\"ovblx\":\"dataicmhhv\",\"kfzsouou\":\"dataylezgdpiurfemn\",\"qldgii\":\"datazszlrv\"}},\"name\":\"npkxp\",\"description\":\"utyjfhjhbvlljk\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"kbf\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Succeeded\"],\"\":{\"cvw\":\"datadrbtgmfpdre\",\"fdedeuphg\":\"databsdyxqjyrqouyf\"}},{\"activity\":\"f\",\"dependencyConditions\":[\"Succeeded\",\"Failed\"],\"\":{\"dhw\":\"dataeboelksghsowmvtm\",\"c\":\"datafbjhhpfj\"}},{\"activity\":\"l\",\"dependencyConditions\":[\"Failed\",\"Failed\"],\"\":{\"tldijg\":\"dataopecjmovrs\",\"iluzokxphcjtwh\":\"databitudwuoxir\",\"jmgctwamjjw\":\"datagb\"}},{\"activity\":\"mugis\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Completed\"],\"\":{\"tdyxzg\":\"dataopedmk\",\"rvkqxhkhj\":\"dataqtgfbmocvb\",\"yrqtu\":\"datarcqpxaajt\",\"ssbvlj\":\"datatzmubxngspazm\"}}],\"userProperties\":[{\"name\":\"be\",\"value\":\"datauhwcakkewgzao\"}],\"\":{\"vahqjdi\":\"datalqtjjewezcknpm\",\"ehudicxolmmhfd\":\"datajoldwa\",\"jqvmpzcjvogr\":\"datavxoiwb\",\"ydespwwkdmsnez\":\"dataipop\"}}")
+ "{\"type\":\"HDInsightMapReduce\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"rnlbfnuppwqkskns\",\"parameters\":{\"cx\":\"datakjboyggrmz\",\"gmtgoeayhojdgwez\":\"dataphdkxwstabgejopv\"}},{\"referenceName\":\"r\",\"parameters\":{\"dtj\":\"databdjzcfdpxbwqgkfx\",\"bc\":\"datayevvuddnwj\"}},{\"referenceName\":\"flemxbmaiiv\",\"parameters\":{\"o\":\"datatzbkevh\",\"sis\":\"datajpumpqlugzydylf\"}},{\"referenceName\":\"dmfo\",\"parameters\":{\"tkprbm\":\"datasvfnxxkmrfz\"}}],\"arguments\":[\"datarfhfjwikva\",\"datajx\"],\"getDebugInfo\":\"Always\",\"className\":\"dataqilvajc\",\"jarFilePath\":\"datapwlf\",\"jarLinkedService\":{\"referenceName\":\"ardjqwdrooo\",\"parameters\":{\"vdqcmegwajjzxcq\":\"datasyd\"}},\"jarLibs\":[\"dataxewocwmadyelwo\",\"datalxa\",\"datahanfjrdcaw\",\"datazqldakbijcxctn\"],\"defines\":{\"yhnoll\":\"datayczzwhwsidnqiav\",\"eoxoe\":\"datauhocb\",\"fcurn\":\"dataprtz\",\"stok\":\"dataujcunyua\"}},\"linkedServiceName\":{\"referenceName\":\"myayblmcenjc\",\"parameters\":{\"yubytslfmajswrf\":\"dataamuplxksph\",\"gvkqz\":\"datas\"}},\"policy\":{\"timeout\":\"datas\",\"retry\":\"dataufnhejualug\",\"retryIntervalInSeconds\":1662073469,\"secureInput\":false,\"secureOutput\":true,\"\":{\"s\":\"datalvi\"}},\"name\":\"zwtzdyz\",\"description\":\"gnnsojdmesox\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"h\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Succeeded\"],\"\":{\"xtwsreadghlokvis\":\"databiouuqox\",\"kegrtvwff\":\"datazmheimsioonnfjgr\"}}],\"userProperties\":[{\"name\":\"uxpyveavstzbz\",\"value\":\"datakksdjkanizdcjx\"},{\"name\":\"zpmwxvfrmvtwwb\",\"value\":\"datahivfosbrqeywhlq\"}],\"\":{\"hbqjlly\":\"datahypuvhucaw\",\"dioumgvwb\":\"databqvnbxgk\"}}")
.toObject(HDInsightMapReduceActivity.class);
- Assertions.assertEquals("npkxp", model.name());
- Assertions.assertEquals("utyjfhjhbvlljk", model.description());
+ Assertions.assertEquals("zwtzdyz", model.name());
+ Assertions.assertEquals("gnnsojdmesox", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("kbf", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("h", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("be", model.userProperties().get(0).name());
- Assertions.assertEquals("yyysvtjoxw", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1228339310, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("uxpyveavstzbz", model.userProperties().get(0).name());
+ Assertions.assertEquals("myayblmcenjc", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1662073469, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("elht", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("rnlbfnuppwqkskns", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("uomwyoktzffpcd", model.jarLinkedService().referenceName());
+ Assertions.assertEquals("ardjqwdrooo", model.jarLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HDInsightMapReduceActivity model = new HDInsightMapReduceActivity().withName("npkxp")
- .withDescription("utyjfhjhbvlljk")
+ HDInsightMapReduceActivity model = new HDInsightMapReduceActivity().withName("zwtzdyz")
+ .withDescription("gnnsojdmesox")
.withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("kbf")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED,
- DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("f")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("l")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("mugis")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("be").withValue("datauhwcakkewgzao")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("yyysvtjoxw")
- .withParameters(mapOf("dwoevmocnfzmu", "datazwoczfizfcmpddz", "luwuns", "dataykxlfl", "mgpomcre",
- "datayqpmnyvn", "lilzv", "datataz")))
- .withPolicy(new ActivityPolicy().withTimeout("datadnobxcdx")
- .withRetry("dataraeodixofl")
- .withRetryIntervalInSeconds(1228339310)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("h")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("uxpyveavstzbz").withValue("datakksdjkanizdcjx"),
+ new UserProperty().withName("zpmwxvfrmvtwwb").withValue("datahivfosbrqeywhlq")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("myayblmcenjc")
+ .withParameters(mapOf("yubytslfmajswrf", "dataamuplxksph", "gvkqz", "datas")))
+ .withPolicy(new ActivityPolicy().withTimeout("datas")
+ .withRetry("dataufnhejualug")
+ .withRetryIntervalInSeconds(1662073469)
.withSecureInput(false)
- .withSecureOutput(false)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf()))
.withStorageLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("elht")
- .withParameters(mapOf("cgdpqkfxdqmdvrgl", "dataeimwhot", "tmjuq", "datalvmkeseyq",
- "juwkkvarffjuefj", "dataahmzletac", "odmdrdtywa", "datamowq")),
- new LinkedServiceReference().withReferenceName("qwa")
- .withParameters(mapOf("taqmrimletj", "dataapvcswzjrpcpgclt")),
- new LinkedServiceReference().withReferenceName("zptfgabi")
- .withParameters(mapOf("wgszxupwriz", "datazfglp", "sjpq", "dataqnbiiand"))))
- .withArguments(Arrays.asList("dataku", "dataosltch", "datauhvdrfh"))
+ new LinkedServiceReference().withReferenceName("rnlbfnuppwqkskns")
+ .withParameters(mapOf("cx", "datakjboyggrmz", "gmtgoeayhojdgwez", "dataphdkxwstabgejopv")),
+ new LinkedServiceReference().withReferenceName("r")
+ .withParameters(mapOf("dtj", "databdjzcfdpxbwqgkfx", "bc", "datayevvuddnwj")),
+ new LinkedServiceReference().withReferenceName("flemxbmaiiv")
+ .withParameters(mapOf("o", "datatzbkevh", "sis", "datajpumpqlugzydylf")),
+ new LinkedServiceReference().withReferenceName("dmfo")
+ .withParameters(mapOf("tkprbm", "datasvfnxxkmrfz"))))
+ .withArguments(Arrays.asList("datarfhfjwikva", "datajx"))
.withGetDebugInfo(HDInsightActivityDebugInfoOption.ALWAYS)
- .withClassName("dataxhnojfdiijch")
- .withJarFilePath("dataaaabtxrhemnkyk")
- .withJarLinkedService(new LinkedServiceReference().withReferenceName("uomwyoktzffpcd")
- .withParameters(mapOf("eqvkuvy", "datapz", "rfok", "datai", "bdh", "datalcoikstap")))
- .withJarLibs(Arrays.asList("dataugkugwtg", "dataktwayha", "datahqvxeyl"))
- .withDefines(mapOf("cufzxxqd", "dataatbsghtk", "vqvernqk", "datatv"));
+ .withClassName("dataqilvajc")
+ .withJarFilePath("datapwlf")
+ .withJarLinkedService(new LinkedServiceReference().withReferenceName("ardjqwdrooo")
+ .withParameters(mapOf("vdqcmegwajjzxcq", "datasyd")))
+ .withJarLibs(Arrays.asList("dataxewocwmadyelwo", "datalxa", "datahanfjrdcaw", "datazqldakbijcxctn"))
+ .withDefines(mapOf("yhnoll", "datayczzwhwsidnqiav", "eoxoe", "datauhocb", "fcurn", "dataprtz", "stok",
+ "dataujcunyua"));
model = BinaryData.fromObject(model).toObject(HDInsightMapReduceActivity.class);
- Assertions.assertEquals("npkxp", model.name());
- Assertions.assertEquals("utyjfhjhbvlljk", model.description());
+ Assertions.assertEquals("zwtzdyz", model.name());
+ Assertions.assertEquals("gnnsojdmesox", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("kbf", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("h", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("be", model.userProperties().get(0).name());
- Assertions.assertEquals("yyysvtjoxw", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1228339310, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("uxpyveavstzbz", model.userProperties().get(0).name());
+ Assertions.assertEquals("myayblmcenjc", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1662073469, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("elht", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("rnlbfnuppwqkskns", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("uomwyoktzffpcd", model.jarLinkedService().referenceName());
+ Assertions.assertEquals("ardjqwdrooo", model.jarLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTypePropertiesTests.java
index 044dc15dd877..0de66e452918 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightMapReduceActivityTypePropertiesTests.java
@@ -17,39 +17,36 @@ public final class HDInsightMapReduceActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightMapReduceActivityTypeProperties model = BinaryData.fromString(
- "{\"storageLinkedServices\":[{\"referenceName\":\"jq\",\"parameters\":{\"ep\":\"datagwyqbqmelmqk\"}},{\"referenceName\":\"ehsveaer\",\"parameters\":{\"nstjfkjboyggr\":\"databrnlbfnuppwqks\",\"bgej\":\"dataztcxyphdkxwst\",\"g\":\"datapvegmtgoeayhoj\"}},{\"referenceName\":\"ezcrssmbdjzc\",\"parameters\":{\"dtj\":\"dataxbwqgkfx\",\"bc\":\"datayevvuddnwj\",\"pftzbkev\":\"dataflemxbmaiiv\",\"bjpumpqlugzydyl\":\"datal\"}},{\"referenceName\":\"rsis\",\"parameters\":{\"fzhtkp\":\"datafomiesvfnxxkm\"}}],\"arguments\":[\"datacazrfhfjwikvakj\"],\"getDebugInfo\":\"Always\",\"className\":\"datahqilvajc\",\"jarFilePath\":\"datapwlf\",\"jarLinkedService\":{\"referenceName\":\"ardjqwdrooo\",\"parameters\":{\"vdqcmegwajjzxcq\":\"datasyd\"}},\"jarLibs\":[\"dataxewocwmadyelwo\",\"datalxa\",\"datahanfjrdcaw\",\"datazqldakbijcxctn\"],\"defines\":{\"yhnoll\":\"datayczzwhwsidnqiav\",\"eoxoe\":\"datauhocb\",\"fcurn\":\"dataprtz\",\"stok\":\"dataujcunyua\"}}")
+ "{\"storageLinkedServices\":[{\"referenceName\":\"heqvzwummwuaxxcb\",\"parameters\":{\"qrbtrmi\":\"datacdujhzaiw\"}},{\"referenceName\":\"l\",\"parameters\":{\"ubyfspliw\":\"datadukamtfkufvabci\",\"ajpyuwrggfgll\":\"datakozlpsf\"}},{\"referenceName\":\"su\",\"parameters\":{\"qhugjeaetgmmf\":\"datavytbqqmxkuyyrcqs\",\"upkpyzaenarfy\":\"datafdqoepwyy\"}}],\"arguments\":[\"datai\",\"datakhoygfgchlc\"],\"getDebugInfo\":\"Always\",\"className\":\"datacsskgug\",\"jarFilePath\":\"datakl\",\"jarLinkedService\":{\"referenceName\":\"mymkccclefawfeea\",\"parameters\":{\"gowfqrykikhf\":\"datamm\"}},\"jarLibs\":[\"datacllz\",\"dataazi\",\"dataohtsmkfyox\"],\"defines\":{\"fbiboyex\":\"datafsehbxbqionnqsz\",\"cqjgwtiasfbp\":\"datacrwwdteyvpv\",\"xxhbrysnszsehoe\":\"datamv\"}}")
.toObject(HDInsightMapReduceActivityTypeProperties.class);
- Assertions.assertEquals("jq", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals("heqvzwummwuaxxcb", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("ardjqwdrooo", model.jarLinkedService().referenceName());
+ Assertions.assertEquals("mymkccclefawfeea", model.jarLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
HDInsightMapReduceActivityTypeProperties model = new HDInsightMapReduceActivityTypeProperties()
.withStorageLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("jq").withParameters(mapOf("ep", "datagwyqbqmelmqk")),
- new LinkedServiceReference().withReferenceName("ehsveaer")
- .withParameters(mapOf("nstjfkjboyggr", "databrnlbfnuppwqks", "bgej", "dataztcxyphdkxwst", "g",
- "datapvegmtgoeayhoj")),
- new LinkedServiceReference().withReferenceName("ezcrssmbdjzc")
- .withParameters(mapOf("dtj", "dataxbwqgkfx", "bc", "datayevvuddnwj", "pftzbkev", "dataflemxbmaiiv",
- "bjpumpqlugzydyl", "datal")),
- new LinkedServiceReference().withReferenceName("rsis")
- .withParameters(mapOf("fzhtkp", "datafomiesvfnxxkm"))))
- .withArguments(Arrays.asList("datacazrfhfjwikvakj"))
+ new LinkedServiceReference().withReferenceName("heqvzwummwuaxxcb")
+ .withParameters(mapOf("qrbtrmi", "datacdujhzaiw")),
+ new LinkedServiceReference().withReferenceName("l")
+ .withParameters(mapOf("ubyfspliw", "datadukamtfkufvabci", "ajpyuwrggfgll", "datakozlpsf")),
+ new LinkedServiceReference().withReferenceName("su")
+ .withParameters(mapOf("qhugjeaetgmmf", "datavytbqqmxkuyyrcqs", "upkpyzaenarfy", "datafdqoepwyy"))))
+ .withArguments(Arrays.asList("datai", "datakhoygfgchlc"))
.withGetDebugInfo(HDInsightActivityDebugInfoOption.ALWAYS)
- .withClassName("datahqilvajc")
- .withJarFilePath("datapwlf")
- .withJarLinkedService(new LinkedServiceReference().withReferenceName("ardjqwdrooo")
- .withParameters(mapOf("vdqcmegwajjzxcq", "datasyd")))
- .withJarLibs(Arrays.asList("dataxewocwmadyelwo", "datalxa", "datahanfjrdcaw", "datazqldakbijcxctn"))
- .withDefines(mapOf("yhnoll", "datayczzwhwsidnqiav", "eoxoe", "datauhocb", "fcurn", "dataprtz", "stok",
- "dataujcunyua"));
+ .withClassName("datacsskgug")
+ .withJarFilePath("datakl")
+ .withJarLinkedService(new LinkedServiceReference().withReferenceName("mymkccclefawfeea")
+ .withParameters(mapOf("gowfqrykikhf", "datamm")))
+ .withJarLibs(Arrays.asList("datacllz", "dataazi", "dataohtsmkfyox"))
+ .withDefines(mapOf("fbiboyex", "datafsehbxbqionnqsz", "cqjgwtiasfbp", "datacrwwdteyvpv", "xxhbrysnszsehoe",
+ "datamv"));
model = BinaryData.fromObject(model).toObject(HDInsightMapReduceActivityTypeProperties.class);
- Assertions.assertEquals("jq", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals("heqvzwummwuaxxcb", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("ardjqwdrooo", model.jarLinkedService().referenceName());
+ Assertions.assertEquals("mymkccclefawfeea", model.jarLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTests.java
index 49485182ab1d..0b8a33b99ac4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTests.java
@@ -23,89 +23,75 @@ public final class HDInsightPigActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightPigActivity model = BinaryData.fromString(
- "{\"type\":\"HDInsightPig\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"xoqnvi\",\"parameters\":{\"loe\":\"datacolnxwdppiodnnt\",\"zvi\":\"dataptngr\",\"cdkomr\":\"dataxacxcac\"}},{\"referenceName\":\"u\",\"parameters\":{\"skyrhsijxm\":\"datajxpdqwywjnxd\"}},{\"referenceName\":\"iuymfx\",\"parameters\":{\"gzybp\":\"datawmbdtfet\",\"qkrsnxuezw\":\"datarapghloemqapvnqs\"}},{\"referenceName\":\"bqadtv\",\"parameters\":{\"ejplphkiyiq\":\"datagtmtgkrivcx\",\"sl\":\"dataiiodvzjk\"}}],\"arguments\":\"datadpo\",\"getDebugInfo\":\"Failure\",\"scriptPath\":\"datawpsncxbkwmhjq\",\"scriptLinkedService\":{\"referenceName\":\"acbcbrsnn\",\"parameters\":{\"jkbisjurilqc\":\"datamgfgtwqmtyfqut\"}},\"defines\":{\"ckbizqqajs\":\"datadorbufog\",\"cyvrbgi\":\"dataauwojgvpqzvtgwlz\"}},\"linkedServiceName\":{\"referenceName\":\"rdekjbljfkqubnn\",\"parameters\":{\"dfxxaoyisky\":\"datacbcxbvnhlw\"}},\"policy\":{\"timeout\":\"dataxakbqbwjtnf\",\"retry\":\"datamqkgc\",\"retryIntervalInSeconds\":1300088318,\"secureInput\":false,\"secureOutput\":false,\"\":{\"gszwsnryfaprhfcd\":\"datae\",\"x\":\"databcribqdsz\",\"yknfrhbknragpnmc\":\"dataaqlyw\",\"gd\":\"dataudfxh\"}},\"name\":\"zegm\",\"description\":\"ebzoujhijlduuvxk\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"ordzwbskf\",\"dependencyConditions\":[\"Succeeded\",\"Failed\",\"Completed\",\"Succeeded\"],\"\":{\"pmowlsrxytev\":\"dataojzlia\",\"nzzhyl\":\"dataqxpmfhehtrpql\"}},{\"activity\":\"zuxqqrmck\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"zg\":\"dataeutbym\"}},{\"activity\":\"zhbnbnjpiecnriv\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\"],\"\":{\"uvpcjyh\":\"datahsuhkik\",\"anrirrnqloomsy\":\"dataznmj\",\"gdvknqui\":\"datayqgaska\",\"jzborwzpfgks\":\"dataipgvfchzcpv\"}},{\"activity\":\"vbrxlsbgl\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Completed\",\"Failed\"],\"\":{\"cabsmrfx\":\"dataneopxdbhcfswpdar\"}}],\"userProperties\":[{\"name\":\"vzgwvmhbiziij\",\"value\":\"dataseexdboatvsfyxdf\"},{\"name\":\"qrnawnqy\",\"value\":\"datagfxacojca\"},{\"name\":\"axor\",\"value\":\"dataj\"},{\"name\":\"oyngxogqvwchyn\",\"value\":\"datadtnaptwmawypk\"}],\"\":{\"gvvizaygtbmluyyc\":\"dataidoqvcjspjpmt\",\"uijpay\":\"datazvqpnjqpwxf\",\"i\":\"datalnz\",\"n\":\"dataqopwmbdleegwlh\"}}")
+ "{\"type\":\"HDInsightPig\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"iandhsjpqhas\",\"parameters\":{\"uhvdrfh\":\"dataosltch\",\"nojfdiijch\":\"datarcx\",\"ruomwyoktzffp\":\"dataaaabtxrhemnkyk\"}}],\"arguments\":\"dataqhjpze\",\"getDebugInfo\":\"Failure\",\"scriptPath\":\"datauv\",\"scriptLinkedService\":{\"referenceName\":\"i\",\"parameters\":{\"ikstapkbd\":\"dataokolc\",\"mugkugwtg\":\"datay\"}},\"defines\":{\"tb\":\"datawayhauhqvxeyliis\",\"xxq\":\"dataghtkdcuf\"}},\"linkedServiceName\":{\"referenceName\":\"tv\",\"parameters\":{\"yyysvtjoxw\":\"datavernqke\",\"pddzzdw\":\"datagdzwoczfizfc\",\"ocnfzmuyykxlfl\":\"dataev\"}},\"policy\":{\"timeout\":\"datawunsnyqpmn\",\"retry\":\"datanbmgpomcrev\",\"retryIntervalInSeconds\":1913060476,\"secureInput\":false,\"secureOutput\":true,\"\":{\"cdxpnraeodixo\":\"dataeisdnob\",\"sf\":\"datalxvsuhxrctcozf\",\"rwbcycwasmrfbwsi\":\"databjrbqcb\",\"gd\":\"datamhhvbovblxfyle\"}},\"name\":\"iurfemnykfzsouo\",\"description\":\"zszlrv\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"jnpkxprbutyjfhj\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Skipped\"],\"\":{\"scbmdrbtgm\":\"dataqlruhhkkbfgr\",\"qjyrqouyfcfdedeu\":\"datapdredcvwsbsdy\",\"elksghsowm\":\"datahgnfaanubjeb\"}},{\"activity\":\"t\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"b\":\"datan\",\"c\":\"datahhpfj\"}}],\"userProperties\":[{\"name\":\"pwavdope\",\"value\":\"datajmovrsrtldijgrbi\"},{\"name\":\"udwuoxirzi\",\"value\":\"datau\"},{\"name\":\"okxphcj\",\"value\":\"datawhwgbajmgctwamjj\"}],\"\":{\"hhopedmkxtdyxz\":\"dataugistnyz\",\"tgfbmocvblrvkqx\":\"dataf\"}}")
.toObject(HDInsightPigActivity.class);
- Assertions.assertEquals("zegm", model.name());
- Assertions.assertEquals("ebzoujhijlduuvxk", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("ordzwbskf", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("iurfemnykfzsouo", model.name());
+ Assertions.assertEquals("zszlrv", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("jnpkxprbutyjfhj", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("vzgwvmhbiziij", model.userProperties().get(0).name());
- Assertions.assertEquals("rdekjbljfkqubnn", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1300088318, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("pwavdope", model.userProperties().get(0).name());
+ Assertions.assertEquals("tv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1913060476, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("xoqnvi", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("iandhsjpqhas", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
- Assertions.assertEquals("acbcbrsnn", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals("i", model.scriptLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HDInsightPigActivity model = new HDInsightPigActivity().withName("zegm")
- .withDescription("ebzoujhijlduuvxk")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ HDInsightPigActivity model = new HDInsightPigActivity().withName("iurfemnykfzsouo")
+ .withDescription("zszlrv")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ordzwbskf")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED,
- DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("jnpkxprbutyjfhj")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("zuxqqrmck")
+ new ActivityDependency().withActivity("t")
.withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("zhbnbnjpiecnriv")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("vbrxlsbgl")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
- DependencyCondition.COMPLETED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("vzgwvmhbiziij").withValue("dataseexdboatvsfyxdf"),
- new UserProperty().withName("qrnawnqy").withValue("datagfxacojca"),
- new UserProperty().withName("axor").withValue("dataj"),
- new UserProperty().withName("oyngxogqvwchyn").withValue("datadtnaptwmawypk")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rdekjbljfkqubnn")
- .withParameters(mapOf("dfxxaoyisky", "datacbcxbvnhlw")))
- .withPolicy(new ActivityPolicy().withTimeout("dataxakbqbwjtnf")
- .withRetry("datamqkgc")
- .withRetryIntervalInSeconds(1300088318)
+ .withUserProperties(Arrays.asList(new UserProperty().withName("pwavdope").withValue("datajmovrsrtldijgrbi"),
+ new UserProperty().withName("udwuoxirzi").withValue("datau"),
+ new UserProperty().withName("okxphcj").withValue("datawhwgbajmgctwamjj")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tv")
+ .withParameters(
+ mapOf("yyysvtjoxw", "datavernqke", "pddzzdw", "datagdzwoczfizfc", "ocnfzmuyykxlfl", "dataev")))
+ .withPolicy(new ActivityPolicy().withTimeout("datawunsnyqpmn")
+ .withRetry("datanbmgpomcrev")
+ .withRetryIntervalInSeconds(1913060476)
.withSecureInput(false)
- .withSecureOutput(false)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withStorageLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("xoqnvi")
- .withParameters(mapOf("loe", "datacolnxwdppiodnnt", "zvi", "dataptngr", "cdkomr", "dataxacxcac")),
- new LinkedServiceReference().withReferenceName("u")
- .withParameters(mapOf("skyrhsijxm", "datajxpdqwywjnxd")),
- new LinkedServiceReference().withReferenceName("iuymfx")
- .withParameters(mapOf("gzybp", "datawmbdtfet", "qkrsnxuezw", "datarapghloemqapvnqs")),
- new LinkedServiceReference().withReferenceName("bqadtv")
- .withParameters(mapOf("ejplphkiyiq", "datagtmtgkrivcx", "sl", "dataiiodvzjk"))))
- .withArguments("datadpo")
+ .withStorageLinkedServices(
+ Arrays.asList(new LinkedServiceReference().withReferenceName("iandhsjpqhas")
+ .withParameters(mapOf("uhvdrfh", "dataosltch", "nojfdiijch", "datarcx", "ruomwyoktzffp",
+ "dataaaabtxrhemnkyk"))))
+ .withArguments("dataqhjpze")
.withGetDebugInfo(HDInsightActivityDebugInfoOption.FAILURE)
- .withScriptPath("datawpsncxbkwmhjq")
- .withScriptLinkedService(new LinkedServiceReference().withReferenceName("acbcbrsnn")
- .withParameters(mapOf("jkbisjurilqc", "datamgfgtwqmtyfqut")))
- .withDefines(mapOf("ckbizqqajs", "datadorbufog", "cyvrbgi", "dataauwojgvpqzvtgwlz"));
+ .withScriptPath("datauv")
+ .withScriptLinkedService(new LinkedServiceReference().withReferenceName("i")
+ .withParameters(mapOf("ikstapkbd", "dataokolc", "mugkugwtg", "datay")))
+ .withDefines(mapOf("tb", "datawayhauhqvxeyliis", "xxq", "dataghtkdcuf"));
model = BinaryData.fromObject(model).toObject(HDInsightPigActivity.class);
- Assertions.assertEquals("zegm", model.name());
- Assertions.assertEquals("ebzoujhijlduuvxk", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("ordzwbskf", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("iurfemnykfzsouo", model.name());
+ Assertions.assertEquals("zszlrv", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("jnpkxprbutyjfhj", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("vzgwvmhbiziij", model.userProperties().get(0).name());
- Assertions.assertEquals("rdekjbljfkqubnn", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1300088318, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("pwavdope", model.userProperties().get(0).name());
+ Assertions.assertEquals("tv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1913060476, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("xoqnvi", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("iandhsjpqhas", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
- Assertions.assertEquals("acbcbrsnn", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals("i", model.scriptLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTypePropertiesTests.java
index de05aabc7f04..cd4511f523e9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightPigActivityTypePropertiesTests.java
@@ -17,33 +17,31 @@ public final class HDInsightPigActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightPigActivityTypeProperties model = BinaryData.fromString(
- "{\"storageLinkedServices\":[{\"referenceName\":\"izhydjkmxbgh\",\"parameters\":{\"bjsvuqkbs\":\"datatlf\",\"ugdyfyjeex\":\"dataicoaysargqkgaus\"}},{\"referenceName\":\"lkxvfejdgoj\",\"parameters\":{\"yyyo\":\"dataezekkv\"}},{\"referenceName\":\"jpsmnxccasuh\",\"parameters\":{\"fhfjf\":\"datahmkqyfatdd\"}}],\"arguments\":\"dataoilmwzkxaglw\",\"getDebugInfo\":\"Failure\",\"scriptPath\":\"datafnmxzukhv\",\"scriptLinkedService\":{\"referenceName\":\"cc\",\"parameters\":{\"fu\":\"dataax\",\"tmfimloz\":\"dataccnqfwobnblu\"}},\"defines\":{\"rdcgeormxi\":\"dataxjirfyetl\",\"twiocuha\":\"datawcqhaonmfnf\"}}")
+ "{\"storageLinkedServices\":[{\"referenceName\":\"jsrcqpxaajt\",\"parameters\":{\"azmxssbv\":\"dataqtuztzmubxngs\"}},{\"referenceName\":\"jnatbecuhwcakke\",\"parameters\":{\"q\":\"dataaousj\",\"wezcknpmeva\":\"datajj\"}}],\"arguments\":\"datajdihjoldwah\",\"getDebugInfo\":\"Failure\",\"scriptPath\":\"dataicxolmmhf\",\"scriptLinkedService\":{\"referenceName\":\"vxoiwb\",\"parameters\":{\"zcjvogrripopzy\":\"datavm\"}},\"defines\":{\"rgwy\":\"datapwwkdmsnezdumjqd\",\"sveaerg\":\"databqmelmqkbepie\"}}")
.toObject(HDInsightPigActivityTypeProperties.class);
- Assertions.assertEquals("izhydjkmxbgh", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals("jsrcqpxaajt", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
- Assertions.assertEquals("cc", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals("vxoiwb", model.scriptLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
HDInsightPigActivityTypeProperties model = new HDInsightPigActivityTypeProperties()
.withStorageLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("izhydjkmxbgh")
- .withParameters(mapOf("bjsvuqkbs", "datatlf", "ugdyfyjeex", "dataicoaysargqkgaus")),
- new LinkedServiceReference().withReferenceName("lkxvfejdgoj")
- .withParameters(mapOf("yyyo", "dataezekkv")),
- new LinkedServiceReference().withReferenceName("jpsmnxccasuh")
- .withParameters(mapOf("fhfjf", "datahmkqyfatdd"))))
- .withArguments("dataoilmwzkxaglw")
+ new LinkedServiceReference().withReferenceName("jsrcqpxaajt")
+ .withParameters(mapOf("azmxssbv", "dataqtuztzmubxngs")),
+ new LinkedServiceReference().withReferenceName("jnatbecuhwcakke")
+ .withParameters(mapOf("q", "dataaousj", "wezcknpmeva", "datajj"))))
+ .withArguments("datajdihjoldwah")
.withGetDebugInfo(HDInsightActivityDebugInfoOption.FAILURE)
- .withScriptPath("datafnmxzukhv")
- .withScriptLinkedService(new LinkedServiceReference().withReferenceName("cc")
- .withParameters(mapOf("fu", "dataax", "tmfimloz", "dataccnqfwobnblu")))
- .withDefines(mapOf("rdcgeormxi", "dataxjirfyetl", "twiocuha", "datawcqhaonmfnf"));
+ .withScriptPath("dataicxolmmhf")
+ .withScriptLinkedService(new LinkedServiceReference().withReferenceName("vxoiwb")
+ .withParameters(mapOf("zcjvogrripopzy", "datavm")))
+ .withDefines(mapOf("rgwy", "datapwwkdmsnezdumjqd", "sveaerg", "databqmelmqkbepie"));
model = BinaryData.fromObject(model).toObject(HDInsightPigActivityTypeProperties.class);
- Assertions.assertEquals("izhydjkmxbgh", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals("jsrcqpxaajt", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
- Assertions.assertEquals("cc", model.scriptLinkedService().referenceName());
+ Assertions.assertEquals("vxoiwb", model.scriptLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTests.java
index 555fdd333213..090e75608109 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTests.java
@@ -23,79 +23,75 @@ public final class HDInsightSparkActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightSparkActivity model = BinaryData.fromString(
- "{\"type\":\"HDInsightSpark\",\"typeProperties\":{\"rootPath\":\"datatpgll\",\"entryFilePath\":\"datarrank\",\"arguments\":[\"datatn\",\"datarohlkgzczjwiz\",\"dataulrkw\",\"dataldttggc\"],\"getDebugInfo\":\"None\",\"sparkJobLinkedService\":{\"referenceName\":\"pobenaahdjn\",\"parameters\":{\"wpbvwuqhpph\":\"datahtvpeirhs\",\"zxdlrjspxoty\":\"dataimoecqpqkpnvsua\",\"ugfejiurl\":\"datag\"}},\"className\":\"ftmllcdqvunvngg\",\"proxyUser\":\"datacforuwqbendz\",\"sparkConfig\":{\"qqsvofocppph\":\"datascbsttjdioevif\",\"xsofsirit\":\"datavduuzpiooac\",\"nouxevizzcjnf\":\"dataqqpynr\",\"numpna\":\"dataubctwnfnq\"}},\"linkedServiceName\":{\"referenceName\":\"pkleieafpvbsllyo\",\"parameters\":{\"muylskbvv\":\"datadhnbofeucctppbgz\",\"urxvjdxl\":\"datadftrqsobu\"}},\"policy\":{\"timeout\":\"dataskck\",\"retry\":\"dataxtknywxpmefbn\",\"retryIntervalInSeconds\":342655149,\"secureInput\":true,\"secureOutput\":false,\"\":{\"dnugbisfnbt\":\"datamify\",\"vki\":\"datadrkwridroidhbu\"}},\"name\":\"yhnfqnekpxd\",\"description\":\"e\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"hnsmkt\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Skipped\",\"Skipped\"],\"\":{\"aurviynt\":\"dataolobtzrgxn\",\"zoqtfbjk\":\"datablp\",\"blb\":\"datafkte\",\"fohipijfywmmqz\":\"datangrkjbdaxttoe\"}},{\"activity\":\"znrjws\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Failed\"],\"\":{\"axdiund\":\"datankxj\",\"bfnt\":\"dataawotpiaklefwai\",\"feudcg\":\"datamkeaw\",\"ffnngiu\":\"dataljbnfw\"}},{\"activity\":\"bpgskgpwspxhhnv\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Completed\"],\"\":{\"wefstize\":\"datatgmd\"}}],\"userProperties\":[{\"name\":\"gzc\",\"value\":\"databgwl\"}],\"\":{\"jpxpwxabvxwoa\":\"dataddflckum\",\"ozkm\":\"dataoeillszdgy\",\"yrwdmgrfhvew\":\"databzuilynbdvbuxlji\"}}")
+ "{\"type\":\"HDInsightSpark\",\"typeProperties\":{\"rootPath\":\"datafkte\",\"entryFilePath\":\"datablb\",\"arguments\":[\"datarkjb\",\"dataaxttoenfohipijfy\",\"datammqzbznrjw\",\"dataecktcwgnkxjd\"],\"getDebugInfo\":\"Always\",\"sparkJobLinkedService\":{\"referenceName\":\"u\",\"parameters\":{\"bfnt\":\"dataawotpiaklefwai\",\"feudcg\":\"datamkeaw\",\"ffnngiu\":\"dataljbnfw\"}},\"className\":\"pgskgpw\",\"proxyUser\":\"dataxh\",\"sparkConfig\":{\"dlwefstizemakgzc\":\"dataxpzjtiktg\"}},\"linkedServiceName\":{\"referenceName\":\"gwllnmddflckumjj\",\"parameters\":{\"agoeillsz\":\"datawxabvxw\",\"ozkm\":\"datagy\",\"yrwdmgrfhvew\":\"databzuilynbdvbuxlji\"}},\"policy\":{\"timeout\":\"datamybokqpfhswbpjz\",\"retry\":\"datazydlyszthpn\",\"retryIntervalInSeconds\":1123609839,\"secureInput\":false,\"secureOutput\":true,\"\":{\"umerkgmg\":\"datagd\",\"kas\":\"dataynej\"}},\"name\":\"iczvfxoihcqxe\",\"description\":\"ksafn\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"uujyespcg\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Succeeded\",\"Completed\"],\"\":{\"iwiaqrc\":\"dataieyyww\",\"w\":\"datafybktbviaqvzzszc\",\"vygdefpy\":\"datarxo\",\"grdsmravxtgl\":\"datatwwaxx\"}},{\"activity\":\"xmd\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Succeeded\",\"Skipped\"],\"\":{\"ypcwbyrkx\":\"datamnqcgbi\",\"chegeog\":\"dataebvxu\",\"wzzeumadl\":\"datakcrc\"}}],\"userProperties\":[{\"name\":\"rewhuqkic\",\"value\":\"datamyykmk\"},{\"name\":\"lbq\",\"value\":\"datanrmgefxkattpkkw\"},{\"name\":\"dvksigxak\",\"value\":\"dataoptb\"}],\"\":{\"bxk\":\"dataqobpnkvnuwjrx\",\"tglo\":\"dataveqbx\",\"jhyiey\":\"datafmlbhlimgzimtzz\",\"xalvdhmumsmnub\":\"datarwfu\"}}")
.toObject(HDInsightSparkActivity.class);
- Assertions.assertEquals("yhnfqnekpxd", model.name());
- Assertions.assertEquals("e", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("hnsmkt", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("gzc", model.userProperties().get(0).name());
- Assertions.assertEquals("pkleieafpvbsllyo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(342655149, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.NONE, model.getDebugInfo());
- Assertions.assertEquals("pobenaahdjn", model.sparkJobLinkedService().referenceName());
- Assertions.assertEquals("ftmllcdqvunvngg", model.className());
+ Assertions.assertEquals("iczvfxoihcqxe", model.name());
+ Assertions.assertEquals("ksafn", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("uujyespcg", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("rewhuqkic", model.userProperties().get(0).name());
+ Assertions.assertEquals("gwllnmddflckumjj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1123609839, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
+ Assertions.assertEquals("u", model.sparkJobLinkedService().referenceName());
+ Assertions.assertEquals("pgskgpw", model.className());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HDInsightSparkActivity model
- = new HDInsightSparkActivity().withName("yhnfqnekpxd")
- .withDescription("e")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("hnsmkt")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SKIPPED, DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("znrjws")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("bpgskgpwspxhhnv")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("gzc").withValue("databgwl")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("pkleieafpvbsllyo")
- .withParameters(mapOf("muylskbvv", "datadhnbofeucctppbgz", "urxvjdxl", "datadftrqsobu")))
- .withPolicy(new ActivityPolicy().withTimeout("dataskck")
- .withRetry("dataxtknywxpmefbn")
- .withRetryIntervalInSeconds(342655149)
- .withSecureInput(true)
- .withSecureOutput(false)
- .withAdditionalProperties(mapOf()))
- .withRootPath("datatpgll")
- .withEntryFilePath("datarrank")
- .withArguments(Arrays.asList("datatn", "datarohlkgzczjwiz", "dataulrkw", "dataldttggc"))
- .withGetDebugInfo(HDInsightActivityDebugInfoOption.NONE)
- .withSparkJobLinkedService(new LinkedServiceReference().withReferenceName("pobenaahdjn")
- .withParameters(mapOf("wpbvwuqhpph", "datahtvpeirhs", "zxdlrjspxoty", "dataimoecqpqkpnvsua",
- "ugfejiurl", "datag")))
- .withClassName("ftmllcdqvunvngg")
- .withProxyUser("datacforuwqbendz")
- .withSparkConfig(mapOf("qqsvofocppph", "datascbsttjdioevif", "xsofsirit", "datavduuzpiooac",
- "nouxevizzcjnf", "dataqqpynr", "numpna", "dataubctwnfnq"));
+ HDInsightSparkActivity model = new HDInsightSparkActivity().withName("iczvfxoihcqxe")
+ .withDescription("ksafn")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("uujyespcg")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.COMPLETED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("xmd")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("rewhuqkic").withValue("datamyykmk"),
+ new UserProperty().withName("lbq").withValue("datanrmgefxkattpkkw"),
+ new UserProperty().withName("dvksigxak").withValue("dataoptb")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("gwllnmddflckumjj")
+ .withParameters(
+ mapOf("agoeillsz", "datawxabvxw", "ozkm", "datagy", "yrwdmgrfhvew", "databzuilynbdvbuxlji")))
+ .withPolicy(new ActivityPolicy().withTimeout("datamybokqpfhswbpjz")
+ .withRetry("datazydlyszthpn")
+ .withRetryIntervalInSeconds(1123609839)
+ .withSecureInput(false)
+ .withSecureOutput(true)
+ .withAdditionalProperties(mapOf()))
+ .withRootPath("datafkte")
+ .withEntryFilePath("datablb")
+ .withArguments(Arrays.asList("datarkjb", "dataaxttoenfohipijfy", "datammqzbznrjw", "dataecktcwgnkxjd"))
+ .withGetDebugInfo(HDInsightActivityDebugInfoOption.ALWAYS)
+ .withSparkJobLinkedService(new LinkedServiceReference().withReferenceName("u")
+ .withParameters(mapOf("bfnt", "dataawotpiaklefwai", "feudcg", "datamkeaw", "ffnngiu", "dataljbnfw")))
+ .withClassName("pgskgpw")
+ .withProxyUser("dataxh")
+ .withSparkConfig(mapOf("dlwefstizemakgzc", "dataxpzjtiktg"));
model = BinaryData.fromObject(model).toObject(HDInsightSparkActivity.class);
- Assertions.assertEquals("yhnfqnekpxd", model.name());
- Assertions.assertEquals("e", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("hnsmkt", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("gzc", model.userProperties().get(0).name());
- Assertions.assertEquals("pkleieafpvbsllyo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(342655149, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.NONE, model.getDebugInfo());
- Assertions.assertEquals("pobenaahdjn", model.sparkJobLinkedService().referenceName());
- Assertions.assertEquals("ftmllcdqvunvngg", model.className());
+ Assertions.assertEquals("iczvfxoihcqxe", model.name());
+ Assertions.assertEquals("ksafn", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("uujyespcg", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("rewhuqkic", model.userProperties().get(0).name());
+ Assertions.assertEquals("gwllnmddflckumjj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1123609839, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
+ Assertions.assertEquals("u", model.sparkJobLinkedService().referenceName());
+ Assertions.assertEquals("pgskgpw", model.className());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTypePropertiesTests.java
index 9cec82ed0930..a5daf76c94c3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightSparkActivityTypePropertiesTests.java
@@ -17,30 +17,29 @@ public final class HDInsightSparkActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightSparkActivityTypeProperties model = BinaryData.fromString(
- "{\"rootPath\":\"datavwmybokqpfhs\",\"entryFilePath\":\"databpjzoyzy\",\"arguments\":[\"dataszthpnwzpki\",\"dataefygdaumerkgmgqy\",\"dataejqka\",\"dataxi\"],\"getDebugInfo\":\"None\",\"sparkJobLinkedService\":{\"referenceName\":\"xoihcqxexbksa\",\"parameters\":{\"gpszwvooxieyyww\":\"datacwyrtluujyesp\",\"fybktbviaqvzzszc\":\"dataiwiaqrc\",\"rxo\":\"dataw\",\"twwaxx\":\"datavygdefpy\"}},\"className\":\"rdsmra\",\"proxyUser\":\"datat\",\"sparkConfig\":{\"dlbocecmnqcgbi\":\"dataxmd\",\"ebvxu\":\"dataypcwbyrkx\",\"kcrc\":\"datachegeog\"}}")
+ "{\"rootPath\":\"datanxrpsty\",\"entryFilePath\":\"dataxidqnvhrbfepf\",\"arguments\":[\"datantaaftdysev\",\"datappxthsfux\",\"datalgoexudnbfoorgtx\",\"datalewhbxvr\"],\"getDebugInfo\":\"Failure\",\"sparkJobLinkedService\":{\"referenceName\":\"kwoommqvzz\",\"parameters\":{\"fh\":\"datawfo\"}},\"className\":\"p\",\"proxyUser\":\"dataljajz\",\"sparkConfig\":{\"odgisfejs\":\"datawarbvblatvbjkqy\",\"wi\":\"datap\",\"jwktiyhiyk\":\"dataujyn\"}}")
.toObject(HDInsightSparkActivityTypeProperties.class);
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.NONE, model.getDebugInfo());
- Assertions.assertEquals("xoihcqxexbksa", model.sparkJobLinkedService().referenceName());
- Assertions.assertEquals("rdsmra", model.className());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
+ Assertions.assertEquals("kwoommqvzz", model.sparkJobLinkedService().referenceName());
+ Assertions.assertEquals("p", model.className());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HDInsightSparkActivityTypeProperties model
- = new HDInsightSparkActivityTypeProperties().withRootPath("datavwmybokqpfhs")
- .withEntryFilePath("databpjzoyzy")
- .withArguments(Arrays.asList("dataszthpnwzpki", "dataefygdaumerkgmgqy", "dataejqka", "dataxi"))
- .withGetDebugInfo(HDInsightActivityDebugInfoOption.NONE)
- .withSparkJobLinkedService(new LinkedServiceReference().withReferenceName("xoihcqxexbksa")
- .withParameters(mapOf("gpszwvooxieyyww", "datacwyrtluujyesp", "fybktbviaqvzzszc", "dataiwiaqrc",
- "rxo", "dataw", "twwaxx", "datavygdefpy")))
- .withClassName("rdsmra")
- .withProxyUser("datat")
- .withSparkConfig(mapOf("dlbocecmnqcgbi", "dataxmd", "ebvxu", "dataypcwbyrkx", "kcrc", "datachegeog"));
+ HDInsightSparkActivityTypeProperties model = new HDInsightSparkActivityTypeProperties()
+ .withRootPath("datanxrpsty")
+ .withEntryFilePath("dataxidqnvhrbfepf")
+ .withArguments(Arrays.asList("datantaaftdysev", "datappxthsfux", "datalgoexudnbfoorgtx", "datalewhbxvr"))
+ .withGetDebugInfo(HDInsightActivityDebugInfoOption.FAILURE)
+ .withSparkJobLinkedService(
+ new LinkedServiceReference().withReferenceName("kwoommqvzz").withParameters(mapOf("fh", "datawfo")))
+ .withClassName("p")
+ .withProxyUser("dataljajz")
+ .withSparkConfig(mapOf("odgisfejs", "datawarbvblatvbjkqy", "wi", "datap", "jwktiyhiyk", "dataujyn"));
model = BinaryData.fromObject(model).toObject(HDInsightSparkActivityTypeProperties.class);
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.NONE, model.getDebugInfo());
- Assertions.assertEquals("xoihcqxexbksa", model.sparkJobLinkedService().referenceName());
- Assertions.assertEquals("rdsmra", model.className());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
+ Assertions.assertEquals("kwoommqvzz", model.sparkJobLinkedService().referenceName());
+ Assertions.assertEquals("p", model.className());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTests.java
index d15f8d261d1c..ed2b6b7cfb4d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTests.java
@@ -23,83 +23,77 @@ public final class HDInsightStreamingActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightStreamingActivity model = BinaryData.fromString(
- "{\"type\":\"HDInsightStreaming\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"y\",\"parameters\":{\"xamup\":\"datalmcenjct\",\"yubytslfmajswrf\":\"dataxksph\"}},{\"referenceName\":\"s\",\"parameters\":{\"ufnhejualug\":\"datakqzulosl\"}},{\"referenceName\":\"uxcffbsnlvissyzw\",\"parameters\":{\"kpwbgfhjwchvu\":\"datayzufgnnsojdmesox\",\"xtwsreadghlokvis\":\"databiouuqox\"}}],\"arguments\":[\"dataheimsioonnf\",\"datagrtkeg\",\"datatvwffvbvuxpyveav\"],\"getDebugInfo\":\"Always\",\"mapper\":\"databzykk\",\"reducer\":\"datadjkanizd\",\"input\":\"datajxgzpmwx\",\"output\":\"datafrm\",\"filePaths\":[\"dataww\",\"dataah\",\"datavfosbrqeyw\",\"datalqydhhypuvhucawm\"],\"fileLinkedService\":{\"referenceName\":\"qjllyzb\",\"parameters\":{\"bytzh\":\"databxgkudioumgv\",\"ax\":\"dataqvzwummw\",\"wkqrbtrmifleizd\":\"datacbihgcdujhza\"}},\"combiner\":\"dataam\",\"commandEnvironment\":[\"dataufvabci\",\"dataubyfspliw\"],\"defines\":{\"ggfgl\":\"datazlpsfrajpyuw\",\"mxkuyyrcqs\":\"datalsungzvytbq\",\"fdqoepwyy\":\"dataqhugjeaetgmmf\"}},\"linkedServiceName\":{\"referenceName\":\"pkpyza\",\"parameters\":{\"hoy\":\"datarfyrlqiy\",\"ugyk\":\"datafgchlcbtxcssk\"}},\"policy\":{\"timeout\":\"datamymkccclefawfeea\",\"retry\":\"datanmmo\",\"retryIntervalInSeconds\":5753856,\"secureInput\":true,\"secureOutput\":false,\"\":{\"gwtcll\":\"datakh\"}},\"name\":\"waz\",\"description\":\"ohtsmkfyox\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"bxbqionnqsznfb\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Failed\",\"Failed\"],\"\":{\"wdteyvpv\":\"datar\",\"mv\":\"datacqjgwtiasfbp\",\"vwbykrndxbkvzwq\":\"dataxxhbrysnszsehoe\"}}],\"userProperties\":[{\"name\":\"hlnqyedhyfncw\",\"value\":\"datayfzuw\"}],\"\":{\"zbzedhcxyg\":\"dataaxstnzivvccgtuji\",\"nyoktcgmcthjgb\":\"datahc\"}}")
+ "{\"type\":\"HDInsightStreaming\",\"typeProperties\":{\"storageLinkedServices\":[{\"referenceName\":\"bykrndxbkvzwqgm\",\"parameters\":{\"yfzuw\":\"datanqyedhyfncw\"}},{\"referenceName\":\"saaxstnzi\",\"parameters\":{\"dhcx\":\"datacgtujiwzbz\",\"clnyo\":\"datagj\",\"brxmxqskemtajjf\":\"datatcgmcthj\",\"qpgbticn\":\"datak\"}}],\"arguments\":[\"databocmji\",\"databtvwalha\",\"dataoptiqfui\"],\"getDebugInfo\":\"Failure\",\"mapper\":\"dataap\",\"reducer\":\"dataxsmapd\",\"input\":\"datammwylrv\",\"output\":\"datataelpuxhkuemcbt\",\"filePaths\":[\"datatnrc\",\"dataovhyqexujllewe\",\"datagvqbsyth\",\"datacdckcpf\"],\"fileLinkedService\":{\"referenceName\":\"mgfwxthrcmg\",\"parameters\":{\"senyehmwzgfanke\":\"datagosclhjgckkbn\",\"g\":\"datalorosa\"}},\"combiner\":\"datahzuapkhfhuuizyey\",\"commandEnvironment\":[\"datanidyjffpuuy\"],\"defines\":{\"yml\":\"databpn\",\"fijvaxuv\":\"datatnnsjc\",\"ldaaxglx\":\"datazzp\",\"kebtvnedcclp\":\"databnqyewinlenht\"}},\"linkedServiceName\":{\"referenceName\":\"ntoiviuerrieho\",\"parameters\":{\"tnllkyiqjtxv\":\"datakcayy\",\"idkjo\":\"datagrf\"}},\"policy\":{\"timeout\":\"dataivvo\",\"retry\":\"datasrypfviiwjjqps\",\"retryIntervalInSeconds\":1579312050,\"secureInput\":true,\"secureOutput\":true,\"\":{\"ekhfdlbcucwfc\":\"datanuyusnhn\"}},\"name\":\"ugtcccydldavozmi\",\"description\":\"kvftpgllsrr\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"nrrohlkgzcz\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"ldttggc\":\"dataulrkw\",\"kpobenaahdjn\":\"dataq\",\"tvpeirhstwpbvw\":\"datayc\",\"cqpqkpnvsuaizxdl\":\"dataqhpphjimo\"}}],\"userProperties\":[{\"name\":\"px\",\"value\":\"datatyjgxu\"},{\"name\":\"fejiurldsft\",\"value\":\"datallcdqvunvnggqacf\"}],\"\":{\"uscbsttjdioevif\":\"datawqbendzr\",\"vduuzpiooac\":\"dataqqsvofocppph\",\"qqpynr\":\"dataxsofsirit\"}}")
.toObject(HDInsightStreamingActivity.class);
- Assertions.assertEquals("waz", model.name());
- Assertions.assertEquals("ohtsmkfyox", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("bxbqionnqsznfb", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("ugtcccydldavozmi", model.name());
+ Assertions.assertEquals("kvftpgllsrr", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("nrrohlkgzcz", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("hlnqyedhyfncw", model.userProperties().get(0).name());
- Assertions.assertEquals("pkpyza", model.linkedServiceName().referenceName());
- Assertions.assertEquals(5753856, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("px", model.userProperties().get(0).name());
+ Assertions.assertEquals("ntoiviuerrieho", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1579312050, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("y", model.storageLinkedServices().get(0).referenceName());
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("qjllyzb", model.fileLinkedService().referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("bykrndxbkvzwqgm", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
+ Assertions.assertEquals("mgfwxthrcmg", model.fileLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HDInsightStreamingActivity model
- = new HDInsightStreamingActivity().withName("waz")
- .withDescription("ohtsmkfyox")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("bxbqionnqsznfb")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("hlnqyedhyfncw").withValue("datayfzuw")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("pkpyza")
- .withParameters(mapOf("hoy", "datarfyrlqiy", "ugyk", "datafgchlcbtxcssk")))
- .withPolicy(new ActivityPolicy().withTimeout("datamymkccclefawfeea")
- .withRetry("datanmmo")
- .withRetryIntervalInSeconds(5753856)
- .withSecureInput(true)
- .withSecureOutput(false)
- .withAdditionalProperties(mapOf()))
- .withStorageLinkedServices(
- Arrays
- .asList(
- new LinkedServiceReference().withReferenceName("y")
- .withParameters(mapOf("xamup", "datalmcenjct", "yubytslfmajswrf", "dataxksph")),
- new LinkedServiceReference().withReferenceName("s")
- .withParameters(mapOf("ufnhejualug", "datakqzulosl")),
- new LinkedServiceReference().withReferenceName("uxcffbsnlvissyzw")
- .withParameters(mapOf("kpwbgfhjwchvu", "datayzufgnnsojdmesox", "xtwsreadghlokvis",
- "databiouuqox"))))
- .withArguments(Arrays.asList("dataheimsioonnf", "datagrtkeg", "datatvwffvbvuxpyveav"))
- .withGetDebugInfo(HDInsightActivityDebugInfoOption.ALWAYS)
- .withMapper("databzykk")
- .withReducer("datadjkanizd")
- .withInput("datajxgzpmwx")
- .withOutput("datafrm")
- .withFilePaths(Arrays.asList("dataww", "dataah", "datavfosbrqeyw", "datalqydhhypuvhucawm"))
- .withFileLinkedService(new LinkedServiceReference().withReferenceName("qjllyzb")
- .withParameters(mapOf("bytzh", "databxgkudioumgv", "ax", "dataqvzwummw", "wkqrbtrmifleizd",
- "datacbihgcdujhza")))
- .withCombiner("dataam")
- .withCommandEnvironment(Arrays.asList("dataufvabci", "dataubyfspliw"))
- .withDefines(mapOf("ggfgl", "datazlpsfrajpyuw", "mxkuyyrcqs", "datalsungzvytbq", "fdqoepwyy",
- "dataqhugjeaetgmmf"));
+ HDInsightStreamingActivity model = new HDInsightStreamingActivity().withName("ugtcccydldavozmi")
+ .withDescription("kvftpgllsrr")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("nrrohlkgzcz")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("px").withValue("datatyjgxu"),
+ new UserProperty().withName("fejiurldsft").withValue("datallcdqvunvnggqacf")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ntoiviuerrieho")
+ .withParameters(mapOf("tnllkyiqjtxv", "datakcayy", "idkjo", "datagrf")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataivvo")
+ .withRetry("datasrypfviiwjjqps")
+ .withRetryIntervalInSeconds(1579312050)
+ .withSecureInput(true)
+ .withSecureOutput(true)
+ .withAdditionalProperties(mapOf()))
+ .withStorageLinkedServices(Arrays.asList(
+ new LinkedServiceReference().withReferenceName("bykrndxbkvzwqgm")
+ .withParameters(mapOf("yfzuw", "datanqyedhyfncw")),
+ new LinkedServiceReference().withReferenceName("saaxstnzi")
+ .withParameters(mapOf("dhcx", "datacgtujiwzbz", "clnyo", "datagj", "brxmxqskemtajjf",
+ "datatcgmcthj", "qpgbticn", "datak"))))
+ .withArguments(Arrays.asList("databocmji", "databtvwalha", "dataoptiqfui"))
+ .withGetDebugInfo(HDInsightActivityDebugInfoOption.FAILURE)
+ .withMapper("dataap")
+ .withReducer("dataxsmapd")
+ .withInput("datammwylrv")
+ .withOutput("datataelpuxhkuemcbt")
+ .withFilePaths(Arrays.asList("datatnrc", "dataovhyqexujllewe", "datagvqbsyth", "datacdckcpf"))
+ .withFileLinkedService(new LinkedServiceReference().withReferenceName("mgfwxthrcmg")
+ .withParameters(mapOf("senyehmwzgfanke", "datagosclhjgckkbn", "g", "datalorosa")))
+ .withCombiner("datahzuapkhfhuuizyey")
+ .withCommandEnvironment(Arrays.asList("datanidyjffpuuy"))
+ .withDefines(mapOf("yml", "databpn", "fijvaxuv", "datatnnsjc", "ldaaxglx", "datazzp", "kebtvnedcclp",
+ "databnqyewinlenht"));
model = BinaryData.fromObject(model).toObject(HDInsightStreamingActivity.class);
- Assertions.assertEquals("waz", model.name());
- Assertions.assertEquals("ohtsmkfyox", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("bxbqionnqsznfb", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("ugtcccydldavozmi", model.name());
+ Assertions.assertEquals("kvftpgllsrr", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("nrrohlkgzcz", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("hlnqyedhyfncw", model.userProperties().get(0).name());
- Assertions.assertEquals("pkpyza", model.linkedServiceName().referenceName());
- Assertions.assertEquals(5753856, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("px", model.userProperties().get(0).name());
+ Assertions.assertEquals("ntoiviuerrieho", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1579312050, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("y", model.storageLinkedServices().get(0).referenceName());
- Assertions.assertEquals(HDInsightActivityDebugInfoOption.ALWAYS, model.getDebugInfo());
- Assertions.assertEquals("qjllyzb", model.fileLinkedService().referenceName());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("bykrndxbkvzwqgm", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
+ Assertions.assertEquals("mgfwxthrcmg", model.fileLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTypePropertiesTests.java
index 596cc9216cfd..32b8b061d0fb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HDInsightStreamingActivityTypePropertiesTests.java
@@ -17,43 +17,36 @@ public final class HDInsightStreamingActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HDInsightStreamingActivityTypeProperties model = BinaryData.fromString(
- "{\"storageLinkedServices\":[{\"referenceName\":\"xqskem\",\"parameters\":{\"bticnidubo\":\"datajfmkwqp\"}},{\"referenceName\":\"mjiib\",\"parameters\":{\"fuiav\":\"dataalhawopti\",\"xsmapd\":\"dataap\"}},{\"referenceName\":\"mmwylrv\",\"parameters\":{\"mcbtumt\":\"dataelpuxhku\",\"hyqexujll\":\"datarcvo\"}},{\"referenceName\":\"wee\",\"parameters\":{\"gfwxthrcmgsimgo\":\"databsythycdckcpfom\",\"na\":\"dataclhjgckk\",\"nkeolorosahgcc\":\"dataenyehmwzgf\",\"i\":\"datazuapkhfhuuizyeyf\"}}],\"arguments\":[\"datayjffpuuyky\"],\"getDebugInfo\":\"Failure\",\"mapper\":\"dataneymlct\",\"reducer\":\"datansjcufijvaxuvazz\",\"input\":\"datatld\",\"output\":\"dataaxglxhbnqyewi\",\"filePaths\":[\"dataenhty\",\"datae\",\"datatvnedcclpb\"],\"fileLinkedService\":{\"referenceName\":\"to\",\"parameters\":{\"eho\":\"datauerr\"}},\"combiner\":\"dataqkcayyd\",\"commandEnvironment\":[\"datalkyiq\",\"datatxvxgrftid\"],\"defines\":{\"srypfviiwjjqps\":\"datatvhivvoc\",\"eygmqnuyu\":\"databx\",\"ekhfdlbcucwfc\":\"datanhn\",\"tkv\":\"dataugtcccydldavozmi\"}}")
+ "{\"storageLinkedServices\":[{\"referenceName\":\"u\",\"parameters\":{\"cjnfyubc\":\"dataiz\"}}],\"arguments\":[\"datafnqqnum\",\"datanavfpkleie\"],\"getDebugInfo\":\"Failure\",\"mapper\":\"datavbs\",\"reducer\":\"datalyoriad\",\"input\":\"datanbofeucctppbgzf\",\"output\":\"datauylsk\",\"filePaths\":[\"datavwdftrqso\"],\"fileLinkedService\":{\"referenceName\":\"surxvj\",\"parameters\":{\"nskcksfxtknywx\":\"datab\"}},\"combiner\":\"datae\",\"commandEnvironment\":[\"dataccbvchozkmi\",\"datayxdnugbisfnbt\",\"datadrkwridroidhbu\",\"datavki\"],\"defines\":{\"ddeahfgdjahnsmk\":\"datanfqnekpx\",\"ob\":\"datakhlqdxjdo\",\"aurviynt\":\"datazrgxn\",\"zoqtfbjk\":\"datablp\"}}")
.toObject(HDInsightStreamingActivityTypeProperties.class);
- Assertions.assertEquals("xqskem", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals("u", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
- Assertions.assertEquals("to", model.fileLinkedService().referenceName());
+ Assertions.assertEquals("surxvj", model.fileLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
HDInsightStreamingActivityTypeProperties model = new HDInsightStreamingActivityTypeProperties()
.withStorageLinkedServices(Arrays.asList(
- new LinkedServiceReference().withReferenceName("xqskem")
- .withParameters(mapOf("bticnidubo", "datajfmkwqp")),
- new LinkedServiceReference().withReferenceName("mjiib")
- .withParameters(mapOf("fuiav", "dataalhawopti", "xsmapd", "dataap")),
- new LinkedServiceReference().withReferenceName("mmwylrv")
- .withParameters(mapOf("mcbtumt", "dataelpuxhku", "hyqexujll", "datarcvo")),
- new LinkedServiceReference().withReferenceName("wee")
- .withParameters(mapOf("gfwxthrcmgsimgo", "databsythycdckcpfom", "na", "dataclhjgckk",
- "nkeolorosahgcc", "dataenyehmwzgf", "i", "datazuapkhfhuuizyeyf"))))
- .withArguments(Arrays.asList("datayjffpuuyky"))
+ new LinkedServiceReference().withReferenceName("u").withParameters(mapOf("cjnfyubc", "dataiz"))))
+ .withArguments(Arrays.asList("datafnqqnum", "datanavfpkleie"))
.withGetDebugInfo(HDInsightActivityDebugInfoOption.FAILURE)
- .withMapper("dataneymlct")
- .withReducer("datansjcufijvaxuvazz")
- .withInput("datatld")
- .withOutput("dataaxglxhbnqyewi")
- .withFilePaths(Arrays.asList("dataenhty", "datae", "datatvnedcclpb"))
- .withFileLinkedService(
- new LinkedServiceReference().withReferenceName("to").withParameters(mapOf("eho", "datauerr")))
- .withCombiner("dataqkcayyd")
- .withCommandEnvironment(Arrays.asList("datalkyiq", "datatxvxgrftid"))
- .withDefines(mapOf("srypfviiwjjqps", "datatvhivvoc", "eygmqnuyu", "databx", "ekhfdlbcucwfc", "datanhn",
- "tkv", "dataugtcccydldavozmi"));
+ .withMapper("datavbs")
+ .withReducer("datalyoriad")
+ .withInput("datanbofeucctppbgzf")
+ .withOutput("datauylsk")
+ .withFilePaths(Arrays.asList("datavwdftrqso"))
+ .withFileLinkedService(new LinkedServiceReference().withReferenceName("surxvj")
+ .withParameters(mapOf("nskcksfxtknywx", "datab")))
+ .withCombiner("datae")
+ .withCommandEnvironment(
+ Arrays.asList("dataccbvchozkmi", "datayxdnugbisfnbt", "datadrkwridroidhbu", "datavki"))
+ .withDefines(mapOf("ddeahfgdjahnsmk", "datanfqnekpx", "ob", "datakhlqdxjdo", "aurviynt", "datazrgxn",
+ "zoqtfbjk", "datablp"));
model = BinaryData.fromObject(model).toObject(HDInsightStreamingActivityTypeProperties.class);
- Assertions.assertEquals("xqskem", model.storageLinkedServices().get(0).referenceName());
+ Assertions.assertEquals("u", model.storageLinkedServices().get(0).referenceName());
Assertions.assertEquals(HDInsightActivityDebugInfoOption.FAILURE, model.getDebugInfo());
- Assertions.assertEquals("to", model.fileLinkedService().referenceName());
+ Assertions.assertEquals("surxvj", model.fileLinkedService().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsReadSettingsTests.java
index 4d3a7f6d6a84..8018c4ea9339 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsReadSettingsTests.java
@@ -12,26 +12,26 @@ public final class HdfsReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HdfsReadSettings model = BinaryData.fromString(
- "{\"type\":\"HdfsReadSettings\",\"recursive\":\"dataeajyifeiiriomjd\",\"wildcardFolderPath\":\"datanbtlxrdepqt\",\"wildcardFileName\":\"datahkpko\",\"fileListPath\":\"datavfno\",\"enablePartitionDiscovery\":\"datawhutvcdtgxsyfuh\",\"partitionRootPath\":\"datamzxpsrlbppjqcwc\",\"modifiedDatetimeStart\":\"dataaosk\",\"modifiedDatetimeEnd\":\"dataalljsoasxjjklm\",\"distcpSettings\":{\"resourceManagerEndpoint\":\"datagrosxfdxrc\",\"tempScriptPath\":\"datanmbb\",\"distcpOptions\":\"datauvdceo\"},\"deleteFilesAfterCompletion\":\"datavnomzlre\",\"maxConcurrentConnections\":\"datadskie\",\"disableMetricsCollection\":\"dataaenalepta\",\"\":{\"aodbhgxbadbo\":\"dataol\"}}")
+ "{\"type\":\"HdfsReadSettings\",\"recursive\":\"datamyfrmfclky\",\"wildcardFolderPath\":\"datajyafzzcbohbbavod\",\"wildcardFileName\":\"dataduabqbverbjcts\",\"fileListPath\":\"datavhxnjo\",\"enablePartitionDiscovery\":\"datapc\",\"partitionRootPath\":\"datadlppuk\",\"modifiedDatetimeStart\":\"datamnp\",\"modifiedDatetimeEnd\":\"datanm\",\"distcpSettings\":{\"resourceManagerEndpoint\":\"dataydhbefivozr\",\"tempScriptPath\":\"datazrikwiucvvr\",\"distcpOptions\":\"datapbjgozo\"},\"deleteFilesAfterCompletion\":\"dataamer\",\"maxConcurrentConnections\":\"datactrwrvnsc\",\"disableMetricsCollection\":\"datac\",\"\":{\"fajlgxrsn\":\"datawqqezt\"}}")
.toObject(HdfsReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HdfsReadSettings model = new HdfsReadSettings().withMaxConcurrentConnections("datadskie")
- .withDisableMetricsCollection("dataaenalepta")
- .withRecursive("dataeajyifeiiriomjd")
- .withWildcardFolderPath("datanbtlxrdepqt")
- .withWildcardFileName("datahkpko")
- .withFileListPath("datavfno")
- .withEnablePartitionDiscovery("datawhutvcdtgxsyfuh")
- .withPartitionRootPath("datamzxpsrlbppjqcwc")
- .withModifiedDatetimeStart("dataaosk")
- .withModifiedDatetimeEnd("dataalljsoasxjjklm")
- .withDistcpSettings(new DistcpSettings().withResourceManagerEndpoint("datagrosxfdxrc")
- .withTempScriptPath("datanmbb")
- .withDistcpOptions("datauvdceo"))
- .withDeleteFilesAfterCompletion("datavnomzlre");
+ HdfsReadSettings model = new HdfsReadSettings().withMaxConcurrentConnections("datactrwrvnsc")
+ .withDisableMetricsCollection("datac")
+ .withRecursive("datamyfrmfclky")
+ .withWildcardFolderPath("datajyafzzcbohbbavod")
+ .withWildcardFileName("dataduabqbverbjcts")
+ .withFileListPath("datavhxnjo")
+ .withEnablePartitionDiscovery("datapc")
+ .withPartitionRootPath("datadlppuk")
+ .withModifiedDatetimeStart("datamnp")
+ .withModifiedDatetimeEnd("datanm")
+ .withDistcpSettings(new DistcpSettings().withResourceManagerEndpoint("dataydhbefivozr")
+ .withTempScriptPath("datazrikwiucvvr")
+ .withDistcpOptions("datapbjgozo"))
+ .withDeleteFilesAfterCompletion("dataamer");
model = BinaryData.fromObject(model).toObject(HdfsReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsSourceTests.java
index a04c46167308..86451663a47a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HdfsSourceTests.java
@@ -12,20 +12,20 @@ public final class HdfsSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HdfsSource model = BinaryData.fromString(
- "{\"type\":\"HdfsSource\",\"recursive\":\"datadrvkbcsvnnvk\",\"distcpSettings\":{\"resourceManagerEndpoint\":\"datazldzzjj\",\"tempScriptPath\":\"datazhj\",\"distcpOptions\":\"datangopdvnzndliodaj\"},\"sourceRetryCount\":\"dataszdyv\",\"sourceRetryWait\":\"dataiufbw\",\"maxConcurrentConnections\":\"dataawh\",\"disableMetricsCollection\":\"datah\",\"\":{\"kqajia\":\"dataeedbhnklesvzdv\"}}")
+ "{\"type\":\"HdfsSource\",\"recursive\":\"datay\",\"distcpSettings\":{\"resourceManagerEndpoint\":\"datatsktousybwddpj\",\"tempScriptPath\":\"dataokosugrfizf\",\"distcpOptions\":\"datamaenwhqafzgzmo\"},\"sourceRetryCount\":\"dataqnienctwbimhf\",\"sourceRetryWait\":\"datagnnwxrdl\",\"maxConcurrentConnections\":\"dataqam\",\"disableMetricsCollection\":\"datayyrfpnbyxyg\",\"\":{\"pskdzssxh\":\"datai\"}}")
.toObject(HdfsSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HdfsSource model = new HdfsSource().withSourceRetryCount("dataszdyv")
- .withSourceRetryWait("dataiufbw")
- .withMaxConcurrentConnections("dataawh")
- .withDisableMetricsCollection("datah")
- .withRecursive("datadrvkbcsvnnvk")
- .withDistcpSettings(new DistcpSettings().withResourceManagerEndpoint("datazldzzjj")
- .withTempScriptPath("datazhj")
- .withDistcpOptions("datangopdvnzndliodaj"));
+ HdfsSource model = new HdfsSource().withSourceRetryCount("dataqnienctwbimhf")
+ .withSourceRetryWait("datagnnwxrdl")
+ .withMaxConcurrentConnections("dataqam")
+ .withDisableMetricsCollection("datayyrfpnbyxyg")
+ .withRecursive("datay")
+ .withDistcpSettings(new DistcpSettings().withResourceManagerEndpoint("datatsktousybwddpj")
+ .withTempScriptPath("dataokosugrfizf")
+ .withDistcpOptions("datamaenwhqafzgzmo"));
model = BinaryData.fromObject(model).toObject(HdfsSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveDatasetTypePropertiesTests.java
index dffdd8beb9f3..51bd37fcf5ef 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveDatasetTypePropertiesTests.java
@@ -10,16 +10,16 @@
public final class HiveDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- HiveDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"datanjqhdheosx\",\"table\":\"datafudmpfhwyp\",\"schema\":\"datatjtntc\"}")
- .toObject(HiveDatasetTypeProperties.class);
+ HiveDatasetTypeProperties model
+ = BinaryData.fromString("{\"tableName\":\"datauklx\",\"table\":\"datalmzpyq\",\"schema\":\"datahuecxhgs\"}")
+ .toObject(HiveDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HiveDatasetTypeProperties model = new HiveDatasetTypeProperties().withTableName("datanjqhdheosx")
- .withTable("datafudmpfhwyp")
- .withSchema("datatjtntc");
+ HiveDatasetTypeProperties model = new HiveDatasetTypeProperties().withTableName("datauklx")
+ .withTable("datalmzpyq")
+ .withSchema("datahuecxhgs");
model = BinaryData.fromObject(model).toObject(HiveDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveObjectDatasetTests.java
index 84d076bc7e36..b82d62e5ca05 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveObjectDatasetTests.java
@@ -19,35 +19,33 @@ public final class HiveObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HiveObjectDataset model = BinaryData.fromString(
- "{\"type\":\"HiveObject\",\"typeProperties\":{\"tableName\":\"datazsggd\",\"table\":\"datatfcbrtsrdplqdyza\",\"schema\":\"dataasfzrguzliyvsb\"},\"description\":\"inv\",\"structure\":\"datadjuljgxotuda\",\"schema\":\"datai\",\"linkedServiceName\":{\"referenceName\":\"a\",\"parameters\":{\"l\":\"datahulzugifgsp\"}},\"parameters\":{\"bwmgksrlmspp\":{\"type\":\"Float\",\"defaultValue\":\"datascygimizluk\"},\"zuqix\":{\"type\":\"Int\",\"defaultValue\":\"dataszthjtryjskdiylg\"},\"koe\":{\"type\":\"Int\",\"defaultValue\":\"databqowgvmxwbohxd\"}},\"annotations\":[\"datah\",\"datanakaj\",\"datascmne\",\"datavlumqeumz\"],\"folder\":{\"name\":\"mgqaeivjq\"},\"\":{\"dzahktxvcbic\":\"datarbgbzgfh\",\"tpxjvtwkyjdpayx\":\"dataecthotbkjwh\",\"qztjfkgb\":\"datapqiwuzr\",\"en\":\"dataqqjobsyn\"}}")
+ "{\"type\":\"HiveObject\",\"typeProperties\":{\"tableName\":\"datagjndkvzmxl\",\"table\":\"dataqgdodn\",\"schema\":\"datayipgkmjt\"},\"description\":\"zmdzesimeft\",\"structure\":\"datarfzjlflzagvdavab\",\"schema\":\"dataefcor\",\"linkedServiceName\":{\"referenceName\":\"bidaeb\",\"parameters\":{\"fajw\":\"dataicew\",\"wwsr\":\"dataylciobb\"}},\"parameters\":{\"mnteevfg\":{\"type\":\"Object\",\"defaultValue\":\"dataecuuuex\"}},\"annotations\":[\"dataezraqsddkod\",\"datagxqfkyr\"],\"folder\":{\"name\":\"zzeglwdzfss\"},\"\":{\"ddkkraj\":\"datagaok\"}}")
.toObject(HiveObjectDataset.class);
- Assertions.assertEquals("inv", model.description());
- Assertions.assertEquals("a", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("bwmgksrlmspp").type());
- Assertions.assertEquals("mgqaeivjq", model.folder().name());
+ Assertions.assertEquals("zmdzesimeft", model.description());
+ Assertions.assertEquals("bidaeb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("mnteevfg").type());
+ Assertions.assertEquals("zzeglwdzfss", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HiveObjectDataset model = new HiveObjectDataset().withDescription("inv")
- .withStructure("datadjuljgxotuda")
- .withSchema("datai")
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("a").withParameters(mapOf("l", "datahulzugifgsp")))
- .withParameters(mapOf("bwmgksrlmspp",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datascygimizluk"), "zuqix",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataszthjtryjskdiylg"),
- "koe", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("databqowgvmxwbohxd")))
- .withAnnotations(Arrays.asList("datah", "datanakaj", "datascmne", "datavlumqeumz"))
- .withFolder(new DatasetFolder().withName("mgqaeivjq"))
- .withTableName("datazsggd")
- .withTable("datatfcbrtsrdplqdyza")
- .withSchemaTypePropertiesSchema("dataasfzrguzliyvsb");
+ HiveObjectDataset model = new HiveObjectDataset().withDescription("zmdzesimeft")
+ .withStructure("datarfzjlflzagvdavab")
+ .withSchema("dataefcor")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bidaeb")
+ .withParameters(mapOf("fajw", "dataicew", "wwsr", "dataylciobb")))
+ .withParameters(mapOf("mnteevfg",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataecuuuex")))
+ .withAnnotations(Arrays.asList("dataezraqsddkod", "datagxqfkyr"))
+ .withFolder(new DatasetFolder().withName("zzeglwdzfss"))
+ .withTableName("datagjndkvzmxl")
+ .withTable("dataqgdodn")
+ .withSchemaTypePropertiesSchema("datayipgkmjt");
model = BinaryData.fromObject(model).toObject(HiveObjectDataset.class);
- Assertions.assertEquals("inv", model.description());
- Assertions.assertEquals("a", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("bwmgksrlmspp").type());
- Assertions.assertEquals("mgqaeivjq", model.folder().name());
+ Assertions.assertEquals("zmdzesimeft", model.description());
+ Assertions.assertEquals("bidaeb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("mnteevfg").type());
+ Assertions.assertEquals("zzeglwdzfss", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveSourceTests.java
index adebb3586dab..7cf45258506e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HiveSourceTests.java
@@ -11,19 +11,19 @@ public final class HiveSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HiveSource model = BinaryData.fromString(
- "{\"type\":\"HiveSource\",\"query\":\"datawbqaibkyeysf\",\"queryTimeout\":\"datahdydyybztlylh\",\"additionalColumns\":\"datacjq\",\"sourceRetryCount\":\"datacie\",\"sourceRetryWait\":\"datak\",\"maxConcurrentConnections\":\"dataxf\",\"disableMetricsCollection\":\"datahvecjhbttmhneqd\",\"\":{\"kna\":\"dataeyxxidabqla\",\"ljsfcryqrrsjqt\":\"datacseqo\"}}")
+ "{\"type\":\"HiveSource\",\"query\":\"dataxmobnehbbchtcoel\",\"queryTimeout\":\"datafnpxumgnjmsk\",\"additionalColumns\":\"dataeuogjiowande\",\"sourceRetryCount\":\"dataebpalz\",\"sourceRetryWait\":\"dataptg\",\"maxConcurrentConnections\":\"datarz\",\"disableMetricsCollection\":\"datacfdsvmptnrz\",\"\":{\"ovqpnxpufvggv\":\"datacncdazwtlgora\"}}")
.toObject(HiveSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HiveSource model = new HiveSource().withSourceRetryCount("datacie")
- .withSourceRetryWait("datak")
- .withMaxConcurrentConnections("dataxf")
- .withDisableMetricsCollection("datahvecjhbttmhneqd")
- .withQueryTimeout("datahdydyybztlylh")
- .withAdditionalColumns("datacjq")
- .withQuery("datawbqaibkyeysf");
+ HiveSource model = new HiveSource().withSourceRetryCount("dataebpalz")
+ .withSourceRetryWait("dataptg")
+ .withMaxConcurrentConnections("datarz")
+ .withDisableMetricsCollection("datacfdsvmptnrz")
+ .withQueryTimeout("datafnpxumgnjmsk")
+ .withAdditionalColumns("dataeuogjiowande")
+ .withQuery("dataxmobnehbbchtcoel");
model = BinaryData.fromObject(model).toObject(HiveSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTests.java
index 12035539e45e..d1dc744af4b0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTests.java
@@ -21,43 +21,40 @@ public final class HttpDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HttpDataset model = BinaryData.fromString(
- "{\"type\":\"HttpFile\",\"typeProperties\":{\"relativeUrl\":\"dataxooi\",\"requestMethod\":\"datahiebruptls\",\"requestBody\":\"dataqzgaqsosrnjlvgrg\",\"additionalHeaders\":\"datahuoxrqhjninpesw\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"dataqkgebz\",\"deserializer\":\"datam\",\"\":{\"ojzdvmsnao\":\"dataiu\",\"hdbitq\":\"dataxsxoxvimdvet\",\"omr\":\"databyujs\"}},\"compression\":{\"type\":\"datau\",\"level\":\"datarmsdbvqxgfyg\",\"\":{\"sesboynpytporr\":\"dataxbdpbcehwbd\",\"anetinqxdhnpjne\":\"datakxtfc\",\"mltpmr\":\"datajighd\",\"qhngqqxjbsot\":\"datawvwetqffuxvfh\"}}},\"description\":\"lmr\",\"structure\":\"datau\",\"schema\":\"datadeatwxpx\",\"linkedServiceName\":{\"referenceName\":\"xedhxbboceksra\",\"parameters\":{\"wurxdqhv\":\"datahlugfnlvvk\"}},\"parameters\":{\"ivlqcwyzhndqkzst\":{\"type\":\"Float\",\"defaultValue\":\"datanntfkqpwqcnbn\"},\"eirta\":{\"type\":\"Object\",\"defaultValue\":\"dataecdl\"},\"viudzpsj\":{\"type\":\"Int\",\"defaultValue\":\"datawcimtcau\"},\"unlofwuzebfq\":{\"type\":\"Int\",\"defaultValue\":\"datalujm\"}},\"annotations\":[\"datajbhzyenf\",\"datapetxeudwkh\",\"datalckdoxocjcdevzp\"],\"folder\":{\"name\":\"ortwwyjm\"},\"\":{\"jnnhbcjywkdywks\":\"datalhfxmr\",\"ptplkossjbzv\":\"dataavuafanefic\"}}")
+ "{\"type\":\"HttpFile\",\"typeProperties\":{\"relativeUrl\":\"datayhbceevogir\",\"requestMethod\":\"dataw\",\"requestBody\":\"datatvuxeu\",\"additionalHeaders\":\"datadssijuaxxf\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datapkcpws\",\"deserializer\":\"datannmjun\",\"\":{\"bcyc\":\"dataxcltj\",\"sihxvtac\":\"dataqak\",\"pxpry\":\"datawf\"}},\"compression\":{\"type\":\"datasbubwhzqqgugwlux\",\"level\":\"datatqmmkdhwq\",\"\":{\"ucosvkkeer\":\"dataebagmfpkephuj\",\"lgnuee\":\"datavypaxpjpyi\",\"cgmbg\":\"datafpffbuqxknv\",\"zoksgqhb\":\"datayojfchicpare\"}}},\"description\":\"juxilozbl\",\"structure\":\"datarfldfljwtkbptsfl\",\"schema\":\"dataumbmwgftshfg\",\"linkedServiceName\":{\"referenceName\":\"uxuqiagskoi\",\"parameters\":{\"hskxpa\":\"datai\",\"rjugcfeb\":\"datawkgvnlfueyxfzibr\",\"bvr\":\"dataiuce\"}},\"parameters\":{\"qjzlwrduxntp\":{\"type\":\"String\",\"defaultValue\":\"dataknbdzwilsxry\"}},\"annotations\":[\"datagj\"],\"folder\":{\"name\":\"xfwf\"},\"\":{\"upjckiehdm\":\"dataveyfbkqynlzxeme\"}}")
.toObject(HttpDataset.class);
- Assertions.assertEquals("lmr", model.description());
- Assertions.assertEquals("xedhxbboceksra", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("ivlqcwyzhndqkzst").type());
- Assertions.assertEquals("ortwwyjm", model.folder().name());
+ Assertions.assertEquals("juxilozbl", model.description());
+ Assertions.assertEquals("uxuqiagskoi", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("qjzlwrduxntp").type());
+ Assertions.assertEquals("xfwf", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HttpDataset model = new HttpDataset().withDescription("lmr")
- .withStructure("datau")
- .withSchema("datadeatwxpx")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xedhxbboceksra")
- .withParameters(mapOf("wurxdqhv", "datahlugfnlvvk")))
- .withParameters(mapOf("ivlqcwyzhndqkzst",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datanntfkqpwqcnbn"),
- "eirta", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataecdl"),
- "viudzpsj", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datawcimtcau"),
- "unlofwuzebfq", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datalujm")))
- .withAnnotations(Arrays.asList("datajbhzyenf", "datapetxeudwkh", "datalckdoxocjcdevzp"))
- .withFolder(new DatasetFolder().withName("ortwwyjm"))
- .withRelativeUrl("dataxooi")
- .withRequestMethod("datahiebruptls")
- .withRequestBody("dataqzgaqsosrnjlvgrg")
- .withAdditionalHeaders("datahuoxrqhjninpesw")
- .withFormat(new DatasetStorageFormat().withSerializer("dataqkgebz")
- .withDeserializer("datam")
+ HttpDataset model = new HttpDataset().withDescription("juxilozbl")
+ .withStructure("datarfldfljwtkbptsfl")
+ .withSchema("dataumbmwgftshfg")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("uxuqiagskoi")
+ .withParameters(mapOf("hskxpa", "datai", "rjugcfeb", "datawkgvnlfueyxfzibr", "bvr", "dataiuce")))
+ .withParameters(mapOf("qjzlwrduxntp",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataknbdzwilsxry")))
+ .withAnnotations(Arrays.asList("datagj"))
+ .withFolder(new DatasetFolder().withName("xfwf"))
+ .withRelativeUrl("datayhbceevogir")
+ .withRequestMethod("dataw")
+ .withRequestBody("datatvuxeu")
+ .withAdditionalHeaders("datadssijuaxxf")
+ .withFormat(new DatasetStorageFormat().withSerializer("datapkcpws")
+ .withDeserializer("datannmjun")
.withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("datau")
- .withLevel("datarmsdbvqxgfyg")
+ .withCompression(new DatasetCompression().withType("datasbubwhzqqgugwlux")
+ .withLevel("datatqmmkdhwq")
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(HttpDataset.class);
- Assertions.assertEquals("lmr", model.description());
- Assertions.assertEquals("xedhxbboceksra", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("ivlqcwyzhndqkzst").type());
- Assertions.assertEquals("ortwwyjm", model.folder().name());
+ Assertions.assertEquals("juxilozbl", model.description());
+ Assertions.assertEquals("uxuqiagskoi", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("qjzlwrduxntp").type());
+ Assertions.assertEquals("xfwf", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTypePropertiesTests.java
index efc2a5a99703..2ccc5937e9b1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpDatasetTypePropertiesTests.java
@@ -15,21 +15,21 @@ public final class HttpDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HttpDatasetTypeProperties model = BinaryData.fromString(
- "{\"relativeUrl\":\"datazw\",\"requestMethod\":\"datazuh\",\"requestBody\":\"datatiaczhfjdccjny\",\"additionalHeaders\":\"databt\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datajcgjtjkntomnl\",\"deserializer\":\"datahcdb\",\"\":{\"bdctqxavejoezvwk\":\"databzrrxeyvidcowlr\"}},\"compression\":{\"type\":\"datazgavp\",\"level\":\"datadmdfiekkis\",\"\":{\"a\":\"datayaeknfffysh\",\"tfofhoajjylsyqyj\":\"datajlmlcufbbji\"}}}")
+ "{\"relativeUrl\":\"datao\",\"requestMethod\":\"dataxxxffgmcuanszee\",\"requestBody\":\"datagcgcsapvbcq\",\"additionalHeaders\":\"datausekijhm\",\"format\":{\"type\":\"DatasetStorageFormat\",\"serializer\":\"datank\",\"deserializer\":\"datavpyr\",\"\":{\"j\":\"datarlfqm\",\"vurkmjufavvln\":\"datawynbfvvc\"}},\"compression\":{\"type\":\"datasotmynklnmrz\",\"level\":\"datatvrkkfcwxizkstx\",\"\":{\"vriuvnfazxtvs\":\"datakeipxutc\",\"kqtjwrv\":\"datayyaeiivj\",\"qetxtdqiuspguzlj\":\"datawojoqf\"}}}")
.toObject(HttpDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HttpDatasetTypeProperties model = new HttpDatasetTypeProperties().withRelativeUrl("datazw")
- .withRequestMethod("datazuh")
- .withRequestBody("datatiaczhfjdccjny")
- .withAdditionalHeaders("databt")
- .withFormat(new DatasetStorageFormat().withSerializer("datajcgjtjkntomnl")
- .withDeserializer("datahcdb")
+ HttpDatasetTypeProperties model = new HttpDatasetTypeProperties().withRelativeUrl("datao")
+ .withRequestMethod("dataxxxffgmcuanszee")
+ .withRequestBody("datagcgcsapvbcq")
+ .withAdditionalHeaders("datausekijhm")
+ .withFormat(new DatasetStorageFormat().withSerializer("datank")
+ .withDeserializer("datavpyr")
.withAdditionalProperties(mapOf("type", "DatasetStorageFormat")))
- .withCompression(new DatasetCompression().withType("datazgavp")
- .withLevel("datadmdfiekkis")
+ .withCompression(new DatasetCompression().withType("datasotmynklnmrz")
+ .withLevel("datatvrkkfcwxizkstx")
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(HttpDatasetTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpReadSettingsTests.java
index 0cf672408a07..9f6bffc5a87d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpReadSettingsTests.java
@@ -11,19 +11,19 @@ public final class HttpReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HttpReadSettings model = BinaryData.fromString(
- "{\"type\":\"HttpReadSettings\",\"requestMethod\":\"datamzsekvsuzyowr\",\"requestBody\":\"datavofrenuvp\",\"additionalHeaders\":\"dataltnyyeyj\",\"requestTimeout\":\"datafpbxnretpg\",\"additionalColumns\":\"datatohruqtximrxeyz\",\"maxConcurrentConnections\":\"datanxb\",\"disableMetricsCollection\":\"datayglfyfcsbkjhoxtb\",\"\":{\"pnixdgqjkfvmrn\":\"datapefo\"}}")
+ "{\"type\":\"HttpReadSettings\",\"requestMethod\":\"datavgwvfvsqlyah\",\"requestBody\":\"dataoqk\",\"additionalHeaders\":\"datatnbuzvaxlt\",\"requestTimeout\":\"datanwhictsauv\",\"additionalColumns\":\"dataqzpfpbxljddkk\",\"maxConcurrentConnections\":\"datazsy\",\"disableMetricsCollection\":\"datakcld\",\"\":{\"xewnlpchhczqm\":\"dataeka\"}}")
.toObject(HttpReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HttpReadSettings model = new HttpReadSettings().withMaxConcurrentConnections("datanxb")
- .withDisableMetricsCollection("datayglfyfcsbkjhoxtb")
- .withRequestMethod("datamzsekvsuzyowr")
- .withRequestBody("datavofrenuvp")
- .withAdditionalHeaders("dataltnyyeyj")
- .withRequestTimeout("datafpbxnretpg")
- .withAdditionalColumns("datatohruqtximrxeyz");
+ HttpReadSettings model = new HttpReadSettings().withMaxConcurrentConnections("datazsy")
+ .withDisableMetricsCollection("datakcld")
+ .withRequestMethod("datavgwvfvsqlyah")
+ .withRequestBody("dataoqk")
+ .withAdditionalHeaders("datatnbuzvaxlt")
+ .withRequestTimeout("datanwhictsauv")
+ .withAdditionalColumns("dataqzpfpbxljddkk");
model = BinaryData.fromObject(model).toObject(HttpReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpSourceTests.java
index 4532f8695570..5d6330961931 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HttpSourceTests.java
@@ -11,17 +11,17 @@ public final class HttpSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HttpSource model = BinaryData.fromString(
- "{\"type\":\"HttpSource\",\"httpRequestTimeout\":\"datakaxzrycvac\",\"sourceRetryCount\":\"datazjysyphxeoqm\",\"sourceRetryWait\":\"datahikcei\",\"maxConcurrentConnections\":\"datavosb\",\"disableMetricsCollection\":\"datawrbqooxvprq\",\"\":{\"jnhxufocski\":\"datahqgipqrtnkn\"}}")
+ "{\"type\":\"HttpSource\",\"httpRequestTimeout\":\"dataqtfyuyg\",\"sourceRetryCount\":\"datashchxueaitzgew\",\"sourceRetryWait\":\"datawibtkr\",\"maxConcurrentConnections\":\"datagbzrlfsewusqupkr\",\"disableMetricsCollection\":\"datapmwo\",\"\":{\"rtecfvzslttkp\":\"datainx\"}}")
.toObject(HttpSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HttpSource model = new HttpSource().withSourceRetryCount("datazjysyphxeoqm")
- .withSourceRetryWait("datahikcei")
- .withMaxConcurrentConnections("datavosb")
- .withDisableMetricsCollection("datawrbqooxvprq")
- .withHttpRequestTimeout("datakaxzrycvac");
+ HttpSource model = new HttpSource().withSourceRetryCount("datashchxueaitzgew")
+ .withSourceRetryWait("datawibtkr")
+ .withMaxConcurrentConnections("datagbzrlfsewusqupkr")
+ .withDisableMetricsCollection("datapmwo")
+ .withHttpRequestTimeout("dataqtfyuyg");
model = BinaryData.fromObject(model).toObject(HttpSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotObjectDatasetTests.java
index 12076d2c1c95..075b82266391 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotObjectDatasetTests.java
@@ -19,32 +19,32 @@ public final class HubspotObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HubspotObjectDataset model = BinaryData.fromString(
- "{\"type\":\"HubspotObject\",\"typeProperties\":{\"tableName\":\"datadbbglaecct\"},\"description\":\"fspvjrds\",\"structure\":\"datavrm\",\"schema\":\"dataftyptwjwiyyeo\",\"linkedServiceName\":{\"referenceName\":\"gmc\",\"parameters\":{\"ioxbgom\":\"datamvphwfnugslvfz\",\"zuox\":\"dataueprpmofxnwc\"}},\"parameters\":{\"nnrnkyj\":{\"type\":\"String\",\"defaultValue\":\"dataxajsehb\"},\"gzehczbni\":{\"type\":\"String\",\"defaultValue\":\"datapcbs\"}},\"annotations\":[\"datahsxvppkjeal\",\"datadbewh\",\"datatvbmyzuqfdqdktr\",\"datat\"],\"folder\":{\"name\":\"zhhqngj\"},\"\":{\"mxlffqgdodnkq\":\"datav\",\"zesimef\":\"dataipgkmjtdazm\",\"fzjlflzagvda\":\"datagd\"}}")
+ "{\"type\":\"HubspotObject\",\"typeProperties\":{\"tableName\":\"datamhp\"},\"description\":\"sfgvrvq\",\"structure\":\"datawbdrwroqkljnzpqh\",\"schema\":\"datasarkyulfa\",\"linkedServiceName\":{\"referenceName\":\"ea\",\"parameters\":{\"geytlplslfc\":\"dataqenhekzaz\",\"ksuowt\":\"datae\",\"rhnxzmfvmw\":\"datalkyqfnjo\",\"rawwhyxf\":\"datanrtc\"}},\"parameters\":{\"uns\":{\"type\":\"String\",\"defaultValue\":\"datadmvwn\"}},\"annotations\":[\"dataevzshqykebmps\",\"dataaezc\",\"datadkckr\"],\"folder\":{\"name\":\"qdmhcejstfs\"},\"\":{\"wxqd\":\"datajakgk\",\"wdjox\":\"dataoqzh\",\"sobvcnsb\":\"datakbd\"}}")
.toObject(HubspotObjectDataset.class);
- Assertions.assertEquals("fspvjrds", model.description());
- Assertions.assertEquals("gmc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("nnrnkyj").type());
- Assertions.assertEquals("zhhqngj", model.folder().name());
+ Assertions.assertEquals("sfgvrvq", model.description());
+ Assertions.assertEquals("ea", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("uns").type());
+ Assertions.assertEquals("qdmhcejstfs", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HubspotObjectDataset model = new HubspotObjectDataset().withDescription("fspvjrds")
- .withStructure("datavrm")
- .withSchema("dataftyptwjwiyyeo")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("gmc")
- .withParameters(mapOf("ioxbgom", "datamvphwfnugslvfz", "zuox", "dataueprpmofxnwc")))
- .withParameters(mapOf("nnrnkyj",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataxajsehb"),
- "gzehczbni", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datapcbs")))
- .withAnnotations(Arrays.asList("datahsxvppkjeal", "datadbewh", "datatvbmyzuqfdqdktr", "datat"))
- .withFolder(new DatasetFolder().withName("zhhqngj"))
- .withTableName("datadbbglaecct");
+ HubspotObjectDataset model = new HubspotObjectDataset().withDescription("sfgvrvq")
+ .withStructure("datawbdrwroqkljnzpqh")
+ .withSchema("datasarkyulfa")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ea")
+ .withParameters(mapOf("geytlplslfc", "dataqenhekzaz", "ksuowt", "datae", "rhnxzmfvmw", "datalkyqfnjo",
+ "rawwhyxf", "datanrtc")))
+ .withParameters(
+ mapOf("uns", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datadmvwn")))
+ .withAnnotations(Arrays.asList("dataevzshqykebmps", "dataaezc", "datadkckr"))
+ .withFolder(new DatasetFolder().withName("qdmhcejstfs"))
+ .withTableName("datamhp");
model = BinaryData.fromObject(model).toObject(HubspotObjectDataset.class);
- Assertions.assertEquals("fspvjrds", model.description());
- Assertions.assertEquals("gmc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("nnrnkyj").type());
- Assertions.assertEquals("zhhqngj", model.folder().name());
+ Assertions.assertEquals("sfgvrvq", model.description());
+ Assertions.assertEquals("ea", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("uns").type());
+ Assertions.assertEquals("qdmhcejstfs", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotSourceTests.java
index 9d197991df07..0e13c640a7ee 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/HubspotSourceTests.java
@@ -11,19 +11,19 @@ public final class HubspotSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
HubspotSource model = BinaryData.fromString(
- "{\"type\":\"HubspotSource\",\"query\":\"dataeydmeuimlhyze\",\"queryTimeout\":\"dataivkzrvya\",\"additionalColumns\":\"dataqgyui\",\"sourceRetryCount\":\"dataelyjduzapnopoto\",\"sourceRetryWait\":\"datarrqcaglyt\",\"maxConcurrentConnections\":\"datacbdpczmzuwr\",\"disableMetricsCollection\":\"datahfwce\",\"\":{\"cyfccnwmdpbso\":\"dataaqaviqskylwpq\",\"fxpveruuckrzw\":\"datakn\"}}")
+ "{\"type\":\"HubspotSource\",\"query\":\"datamezfyelf\",\"queryTimeout\":\"databkbhjdkqfj\",\"additionalColumns\":\"datayzj\",\"sourceRetryCount\":\"dataa\",\"sourceRetryWait\":\"datagatynkihb\",\"maxConcurrentConnections\":\"dataxybtowjz\",\"disableMetricsCollection\":\"datapzaenlzjxztg\",\"\":{\"tczzv\":\"dataunvwvaolfg\"}}")
.toObject(HubspotSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- HubspotSource model = new HubspotSource().withSourceRetryCount("dataelyjduzapnopoto")
- .withSourceRetryWait("datarrqcaglyt")
- .withMaxConcurrentConnections("datacbdpczmzuwr")
- .withDisableMetricsCollection("datahfwce")
- .withQueryTimeout("dataivkzrvya")
- .withAdditionalColumns("dataqgyui")
- .withQuery("dataeydmeuimlhyze");
+ HubspotSource model = new HubspotSource().withSourceRetryCount("dataa")
+ .withSourceRetryWait("datagatynkihb")
+ .withMaxConcurrentConnections("dataxybtowjz")
+ .withDisableMetricsCollection("datapzaenlzjxztg")
+ .withQueryTimeout("databkbhjdkqfj")
+ .withAdditionalColumns("datayzj")
+ .withQuery("datamezfyelf");
model = BinaryData.fromObject(model).toObject(HubspotSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergDatasetTests.java
new file mode 100644
index 000000000000..5cc710e719b6
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergDatasetTests.java
@@ -0,0 +1,66 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.generated;
+
+import com.azure.core.util.BinaryData;
+import com.azure.resourcemanager.datafactory.models.DatasetFolder;
+import com.azure.resourcemanager.datafactory.models.DatasetLocation;
+import com.azure.resourcemanager.datafactory.models.IcebergDataset;
+import com.azure.resourcemanager.datafactory.models.LinkedServiceReference;
+import com.azure.resourcemanager.datafactory.models.ParameterSpecification;
+import com.azure.resourcemanager.datafactory.models.ParameterType;
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.Map;
+import org.junit.jupiter.api.Assertions;
+
+public final class IcebergDatasetTests {
+ @org.junit.jupiter.api.Test
+ public void testDeserialize() throws Exception {
+ IcebergDataset model = BinaryData.fromString(
+ "{\"type\":\"Iceberg\",\"typeProperties\":{\"location\":{\"type\":\"DatasetLocation\",\"folderPath\":\"dataufpnezsjzaymld\",\"fileName\":\"datar\",\"\":{\"uwdhtq\":\"datagzmsimehtc\",\"gi\":\"datahyhnimxtns\",\"ymicjixx\":\"datanomwnwnghojovke\",\"ebdvey\":\"datasfpcrtnuguefxxij\"}}},\"description\":\"tkrhlolmc\",\"structure\":\"dataepfgsvbbvaqdl\",\"schema\":\"datapetlrn\",\"linkedServiceName\":{\"referenceName\":\"detawevxehue\",\"parameters\":{\"zvdov\":\"datal\",\"dcb\":\"datarblerlprdaqcc\",\"ykdigqzlrznda\":\"dataygdjccxwbpw\"}},\"parameters\":{\"tgkiqlarh\":{\"type\":\"Int\",\"defaultValue\":\"datamjqmv\"},\"azekdzdzffzjwzts\":{\"type\":\"Int\",\"defaultValue\":\"datav\"},\"atig\":{\"type\":\"String\",\"defaultValue\":\"datahggryelgf\"}},\"annotations\":[\"datarrkdknczgor\",\"datawnvojtvmdev\",\"datalhqvbk\",\"datarbpyhssrl\"],\"folder\":{\"name\":\"kpkocm\"},\"\":{\"vspeslhwyykgvr\":\"dataebxxopyic\",\"gajkrdyddtpfcud\":\"datacpumdd\"}}")
+ .toObject(IcebergDataset.class);
+ Assertions.assertEquals("tkrhlolmc", model.description());
+ Assertions.assertEquals("detawevxehue", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("tgkiqlarh").type());
+ Assertions.assertEquals("kpkocm", model.folder().name());
+ }
+
+ @org.junit.jupiter.api.Test
+ public void testSerialize() throws Exception {
+ IcebergDataset model = new IcebergDataset().withDescription("tkrhlolmc")
+ .withStructure("dataepfgsvbbvaqdl")
+ .withSchema("datapetlrn")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("detawevxehue")
+ .withParameters(
+ mapOf("zvdov", "datal", "dcb", "datarblerlprdaqcc", "ykdigqzlrznda", "dataygdjccxwbpw")))
+ .withParameters(mapOf("tgkiqlarh",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datamjqmv"),
+ "azekdzdzffzjwzts", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datav"),
+ "atig", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datahggryelgf")))
+ .withAnnotations(Arrays.asList("datarrkdknczgor", "datawnvojtvmdev", "datalhqvbk", "datarbpyhssrl"))
+ .withFolder(new DatasetFolder().withName("kpkocm"))
+ .withLocation(new DatasetLocation().withFolderPath("dataufpnezsjzaymld")
+ .withFileName("datar")
+ .withAdditionalProperties(mapOf("type", "DatasetLocation")));
+ model = BinaryData.fromObject(model).toObject(IcebergDataset.class);
+ Assertions.assertEquals("tkrhlolmc", model.description());
+ Assertions.assertEquals("detawevxehue", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("tgkiqlarh").type());
+ Assertions.assertEquals("kpkocm", model.folder().name());
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergDatasetTypePropertiesTests.java
new file mode 100644
index 000000000000..bc30d8276bcf
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergDatasetTypePropertiesTests.java
@@ -0,0 +1,41 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.generated;
+
+import com.azure.core.util.BinaryData;
+import com.azure.resourcemanager.datafactory.fluent.models.IcebergDatasetTypeProperties;
+import com.azure.resourcemanager.datafactory.models.DatasetLocation;
+import java.util.HashMap;
+import java.util.Map;
+
+public final class IcebergDatasetTypePropertiesTests {
+ @org.junit.jupiter.api.Test
+ public void testDeserialize() throws Exception {
+ IcebergDatasetTypeProperties model = BinaryData.fromString(
+ "{\"location\":{\"type\":\"DatasetLocation\",\"folderPath\":\"datafnbfbq\",\"fileName\":\"datanqnxhgkordwzej\",\"\":{\"cmbpwdlu\":\"datawz\",\"mtffbvtzldzchuba\":\"dataayprldid\"}}}")
+ .toObject(IcebergDatasetTypeProperties.class);
+ }
+
+ @org.junit.jupiter.api.Test
+ public void testSerialize() throws Exception {
+ IcebergDatasetTypeProperties model
+ = new IcebergDatasetTypeProperties().withLocation(new DatasetLocation().withFolderPath("datafnbfbq")
+ .withFileName("datanqnxhgkordwzej")
+ .withAdditionalProperties(mapOf("type", "DatasetLocation")));
+ model = BinaryData.fromObject(model).toObject(IcebergDatasetTypeProperties.class);
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergSinkTests.java
new file mode 100644
index 000000000000..322fc3260340
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergSinkTests.java
@@ -0,0 +1,52 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.generated;
+
+import com.azure.core.util.BinaryData;
+import com.azure.resourcemanager.datafactory.models.IcebergSink;
+import com.azure.resourcemanager.datafactory.models.IcebergWriteSettings;
+import com.azure.resourcemanager.datafactory.models.MetadataItem;
+import com.azure.resourcemanager.datafactory.models.StoreWriteSettings;
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.Map;
+
+public final class IcebergSinkTests {
+ @org.junit.jupiter.api.Test
+ public void testDeserialize() throws Exception {
+ IcebergSink model = BinaryData.fromString(
+ "{\"type\":\"IcebergSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"databznjngerwo\",\"disableMetricsCollection\":\"dataps\",\"copyBehavior\":\"dataoslqmftkqzafjy\",\"metadata\":[{\"name\":\"databzbaboeeg\",\"value\":\"dataecqyzdyzilo\"}],\"\":{\"hyvnqbhclbbk\":\"databtnhiaqegj\",\"xmjmhclhcqcjn\":\"dataoqzzyrovvna\",\"lrjggvydtjebbacs\":\"datawmbwqgsidaso\",\"apxxbkxwh\":\"datairzt\"}},\"formatSettings\":{\"type\":\"IcebergWriteSettings\",\"\":{\"kbslyqmlgsghcnyb\":\"datacpstf\",\"zogs\":\"datavzltbgwjaepjmkr\",\"sirotj\":\"datazoqjbnfaxcdcmqej\",\"kgqyuvhlpmjpzgjn\":\"dataltugobscpt\"}},\"writeBatchSize\":\"datafozn\",\"writeBatchTimeout\":\"databoumpksxkdjpfsm\",\"sinkRetryCount\":\"datar\",\"sinkRetryWait\":\"datalwlehhqxyjlbk\",\"maxConcurrentConnections\":\"datarrptblsatakz\",\"disableMetricsCollection\":\"datay\",\"\":{\"eyv\":\"datawq\",\"uimvz\":\"datadnjmjies\",\"nxcimalvzxu\":\"datayic\",\"ifbi\":\"datanpaesraire\"}}")
+ .toObject(IcebergSink.class);
+ }
+
+ @org.junit.jupiter.api.Test
+ public void testSerialize() throws Exception {
+ IcebergSink model = new IcebergSink().withWriteBatchSize("datafozn")
+ .withWriteBatchTimeout("databoumpksxkdjpfsm")
+ .withSinkRetryCount("datar")
+ .withSinkRetryWait("datalwlehhqxyjlbk")
+ .withMaxConcurrentConnections("datarrptblsatakz")
+ .withDisableMetricsCollection("datay")
+ .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("databznjngerwo")
+ .withDisableMetricsCollection("dataps")
+ .withCopyBehavior("dataoslqmftkqzafjy")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("databzbaboeeg").withValue("dataecqyzdyzilo")))
+ .withAdditionalProperties(mapOf("type", "StoreWriteSettings")))
+ .withFormatSettings(new IcebergWriteSettings());
+ model = BinaryData.fromObject(model).toObject(IcebergSink.class);
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergWriteSettingsTests.java
new file mode 100644
index 000000000000..7eabc9739141
--- /dev/null
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IcebergWriteSettingsTests.java
@@ -0,0 +1,23 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) AutoRest Code Generator.
+
+package com.azure.resourcemanager.datafactory.generated;
+
+import com.azure.core.util.BinaryData;
+import com.azure.resourcemanager.datafactory.models.IcebergWriteSettings;
+
+public final class IcebergWriteSettingsTests {
+ @org.junit.jupiter.api.Test
+ public void testDeserialize() throws Exception {
+ IcebergWriteSettings model
+ = BinaryData.fromString("{\"type\":\"IcebergWriteSettings\",\"\":{\"djbyfdfuaj\":\"datauobzz\"}}")
+ .toObject(IcebergWriteSettings.class);
+ }
+
+ @org.junit.jupiter.api.Test
+ public void testSerialize() throws Exception {
+ IcebergWriteSettings model = new IcebergWriteSettings();
+ model = BinaryData.fromObject(model).toObject(IcebergWriteSettings.class);
+ }
+}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTests.java
index 3aaf73987e5f..74e0fdfd30a3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTests.java
@@ -22,192 +22,143 @@ public final class IfConditionActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
IfConditionActivity model = BinaryData.fromString(
- "{\"type\":\"IfCondition\",\"typeProperties\":{\"expression\":{\"value\":\"pvbmbf\"},\"ifTrueActivities\":[{\"type\":\"Activity\",\"name\":\"uamdydkdcvowasl\",\"description\":\"w\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"tiefxhaqqavhfd\",\"dependencyConditions\":[\"Failed\",\"Completed\"],\"\":{\"vmymfaiw\":\"datajblmypuon\",\"xsqcvabyzdaroe\":\"datalrphadd\",\"typzziavg\":\"datawipaucl\",\"zyfldjkkvaci\":\"dataskvvnznghboqeu\"}},{\"activity\":\"daejn\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"frb\":\"datafuqqb\"}}],\"userProperties\":[{\"name\":\"p\",\"value\":\"datakvok\"},{\"name\":\"mere\",\"value\":\"datanoessuwkcnhdecxb\"},{\"name\":\"knfepixf\",\"value\":\"dataojxbyxfxdnt\"},{\"name\":\"ksbtige\",\"value\":\"datawaidqzf\"}],\"\":{\"lumrzfdb\":\"datavahbqoojdnmrx\",\"qlrmbgiaoxpfko\":\"datatnkadanl\",\"xezurhgucns\":\"datavc\",\"ibgczkk\":\"datapbleazvyftklbb\"}},{\"type\":\"Activity\",\"name\":\"rl\",\"description\":\"dkwibdri\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"lhecztmwwmybv\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Succeeded\",\"Completed\"],\"\":{\"udskcadkyoo\":\"datajglponkrhpyed\",\"f\":\"datavqpcjr\"}},{\"activity\":\"yduzzyx\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Completed\"],\"\":{\"nectfpbfgmghohox\":\"dataufmy\",\"vqcxrrkc\":\"dataonts\",\"zs\":\"dataclqlibpmfn\"}}],\"userProperties\":[{\"name\":\"kktlodsyyzmf\",\"value\":\"datagzljgrtfic\"},{\"name\":\"ejmzbasxapcegtc\",\"value\":\"dataufet\"}],\"\":{\"xgxqdmvfdocjaf\":\"datatjnneynmgvqysghk\",\"wmtfjzuqhyqvm\":\"datafiddnktutwcz\",\"dpeedzowverhtyc\":\"databsj\",\"mdsisll\":\"dataigtsrrlelpobm\"}}],\"ifFalseActivities\":[{\"type\":\"Activity\",\"name\":\"l\",\"description\":\"riimojozhd\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"fqb\",\"dependencyConditions\":[\"Skipped\",\"Completed\"],\"\":{\"ngiff\":\"dataudcvqeowepvn\"}},{\"activity\":\"ntopfqguovqqrc\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Skipped\"],\"\":{\"kefowncudcrw\":\"dataagurgurpcguwyuz\",\"jca\":\"dataiqsrqebjgof\"}},{\"activity\":\"d\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Skipped\"],\"\":{\"mseao\":\"dataf\",\"bslwxcf\":\"dataq\",\"wnmnxppgfep\":\"datavedxyeba\"}}],\"userProperties\":[{\"name\":\"djva\",\"value\":\"dataae\"},{\"name\":\"oqknz\",\"value\":\"datanvvkfbmrppjf\"},{\"name\":\"eabgpw\",\"value\":\"datas\"}],\"\":{\"n\":\"datai\",\"telimqxwih\":\"datavdjmvzcycg\",\"hz\":\"datapyexjrguziglr\",\"isklotwnppstpq\":\"datamrvgcbf\"}},{\"type\":\"Activity\",\"name\":\"s\",\"description\":\"awolhlfffeznb\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ywiscoq\",\"dependencyConditions\":[\"Completed\"],\"\":{\"qkcikfeshxo\":\"datapchdpdevcmp\",\"d\":\"datatvkxpsxlpypzgdet\",\"sutspocrskkraap\":\"datagyhu\"}}],\"userProperties\":[{\"name\":\"ziif\",\"value\":\"datajigtqyzoc\"}],\"\":{\"bwdfjcep\":\"datawcflciooxybmk\"}},{\"type\":\"Activity\",\"name\":\"cpwtj\",\"description\":\"uhrtqn\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"kns\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Skipped\"],\"\":{\"vejxh\":\"datawo\"}},{\"activity\":\"eolzftfyjcen\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Completed\"],\"\":{\"wyyyerzbmlhgytk\":\"dataxh\",\"jftcrjoh\":\"datahevodddnegwsyxdf\"}},{\"activity\":\"i\",\"dependencyConditions\":[\"Failed\"],\"\":{\"rjxkphaq\":\"datatcqjgcdltwlpu\"}}],\"userProperties\":[{\"name\":\"jufljqz\",\"value\":\"dataixlzaavvuvhyerj\"}],\"\":{\"spli\":\"datayxepllbneepfjib\"}},{\"type\":\"Activity\",\"name\":\"fqjweigywj\",\"description\":\"p\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"efdqnsuaoml\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Skipped\",\"Completed\"],\"\":{\"mcrllecquo\":\"datanane\"}}],\"userProperties\":[{\"name\":\"hkv\",\"value\":\"dataofxkelwvcyprpog\"},{\"name\":\"qvuftkiyghcmpyki\",\"value\":\"dataochpzcgs\"},{\"name\":\"pklfnst\",\"value\":\"datat\"}],\"\":{\"esf\":\"datawotk\",\"d\":\"datarsgfpds\",\"fun\":\"dataivepmtt\",\"oczoiduk\":\"datakcji\"}}]},\"name\":\"jjfne\",\"description\":\"qalwjcqbnvbzem\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"cehlgryvkubfotgi\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"fttsdtnqlggtrjzi\":\"datakirxy\",\"cinjej\":\"dataxzbu\",\"jzenagmhhmgtbqzf\":\"datainlysguladd\",\"qcprbwsndloldx\":\"datampgibmngb\"}}],\"userProperties\":[{\"name\":\"j\",\"value\":\"datajyx\"},{\"name\":\"euqcbgbs\",\"value\":\"datagxak\"},{\"name\":\"kbryolzbmdntajgg\",\"value\":\"datauyokctymsbhdi\"}],\"\":{\"pwwfei\":\"dataobsenxgkjfuwtluk\"}}")
+ "{\"type\":\"IfCondition\",\"typeProperties\":{\"expression\":{\"value\":\"ygzaya\"},\"ifTrueActivities\":[{\"type\":\"Activity\",\"name\":\"mlae\",\"description\":\"hucxmybuqjpgbiya\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"inhpvbmbfi\",\"dependencyConditions\":[\"Completed\",\"Failed\"],\"\":{\"wasl\":\"dataydkdcv\",\"otief\":\"datawwgzyvo\",\"kjblmypuonuvmym\":\"datahaqqavhfdezom\"}},{\"activity\":\"aiwxlrphaddsxs\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"roedwipauclety\":\"datayzd\"}}],\"userProperties\":[{\"name\":\"iavguskvvnzngh\",\"value\":\"dataoqe\"}],\"\":{\"jkkvacizdaejn\":\"datayfl\",\"wyfuqqbafrbhr\":\"datab\",\"kvok\":\"datap\"}},{\"type\":\"Activity\",\"name\":\"mere\",\"description\":\"oessuwkcnhdecxbi\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"fdojxbyxfxdnt\",\"dependencyConditions\":[\"Completed\",\"Failed\"],\"\":{\"aidqzflasvah\":\"datageg\",\"ojdnmrxjlumrzfd\":\"dataq\",\"nkadanl\":\"datao\"}},{\"activity\":\"qlrmbgiaoxpfko\",\"dependencyConditions\":[\"Failed\"],\"\":{\"azvyftklb\":\"dataezurhgucnsspbl\",\"dkwibdri\":\"dataribgczkkmrlp\",\"cztmwwmybviwkrje\":\"dataedshuxlh\"}},{\"activity\":\"sjglpon\",\"dependencyConditions\":[\"Completed\",\"Skipped\",\"Skipped\"],\"\":{\"kcad\":\"dataiud\",\"rbfa\":\"datayoouvqpc\",\"wzufmyanectf\":\"dataduzzyxlyuw\"}}],\"userProperties\":[{\"name\":\"g\",\"value\":\"dataghohoxcontsrv\"}],\"\":{\"lqlib\":\"datarrkcv\",\"zs\":\"datamfn\",\"gzljgrtfic\":\"datahkkktlodsyyzmf\"}}],\"ifFalseActivities\":[{\"type\":\"Activity\",\"name\":\"mzbasxapcegtcdu\",\"description\":\"tpkttjnney\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"gh\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Succeeded\",\"Succeeded\"],\"\":{\"jafcfidd\":\"datavfdo\",\"jzuqhyqvmob\":\"dataktutwczdwmt\"}},{\"activity\":\"judpeedzowve\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Completed\",\"Failed\"],\"\":{\"pobmfmdsi\":\"datatsrrle\",\"qgluhr\":\"datall\"}},{\"activity\":\"imojozhdcptxxb\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"cvqeowe\":\"datacmwnyu\",\"fsntopfqgu\":\"datavnrngi\",\"wvzagurgurpc\":\"datavqqrcyeu\",\"yuzhkefownc\":\"datau\"}},{\"activity\":\"dcrwoiqsrqebjgo\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"gchkmqfkm\":\"datad\"}}],\"userProperties\":[{\"name\":\"omq\",\"value\":\"databslwxcf\"},{\"name\":\"vedxyeba\",\"value\":\"datawnmnxppgfep\"},{\"name\":\"nedjvataeao\",\"value\":\"datakn\"},{\"name\":\"ynvv\",\"value\":\"datafbmrppjfceab\"}],\"\":{\"ewi\":\"datazs\",\"vdjmvzcycg\":\"datan\",\"pyexjrguziglr\":\"datatelimqxwih\",\"mrvgcbf\":\"datahz\"}}]},\"name\":\"isklotwnppstpq\",\"description\":\"deawolhl\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"mhqylrsywiscoq\",\"dependencyConditions\":[\"Completed\"],\"\":{\"qkcikfeshxo\":\"datapchdpdevcmp\",\"d\":\"datatvkxpsxlpypzgdet\",\"sutspocrskkraap\":\"datagyhu\"}},{\"activity\":\"zmziiftjig\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Skipped\"],\"\":{\"lciooxybmktbwdfj\":\"datayywc\",\"j\":\"dataepycpw\"}}],\"userProperties\":[{\"name\":\"hrtqnbdgc\",\"value\":\"dataicknsbbc\"},{\"name\":\"bqxwojvejxh\",\"value\":\"dataeolzftfyjcen\"}],\"\":{\"zbmlhgytkthevod\":\"datalpmlxhzwyyye\",\"jftcrjoh\":\"datadnegwsyxdf\",\"bh\":\"datai\"}}")
.toObject(IfConditionActivity.class);
- Assertions.assertEquals("jjfne", model.name());
- Assertions.assertEquals("qalwjcqbnvbzem", model.description());
+ Assertions.assertEquals("isklotwnppstpq", model.name());
+ Assertions.assertEquals("deawolhl", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("cehlgryvkubfotgi", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("j", model.userProperties().get(0).name());
- Assertions.assertEquals("pvbmbf", model.expression().value());
- Assertions.assertEquals("uamdydkdcvowasl", model.ifTrueActivities().get(0).name());
- Assertions.assertEquals("w", model.ifTrueActivities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.ifTrueActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifTrueActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("tiefxhaqqavhfd", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED,
+ Assertions.assertEquals("mhqylrsywiscoq", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("hrtqnbdgc", model.userProperties().get(0).name());
+ Assertions.assertEquals("ygzaya", model.expression().value());
+ Assertions.assertEquals("mlae", model.ifTrueActivities().get(0).name());
+ Assertions.assertEquals("hucxmybuqjpgbiya", model.ifTrueActivities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.ifTrueActivities().get(0).state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.ifTrueActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("inhpvbmbfi", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.ifTrueActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("p", model.ifTrueActivities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("l", model.ifFalseActivities().get(0).name());
- Assertions.assertEquals("riimojozhd", model.ifFalseActivities().get(0).description());
+ Assertions.assertEquals("iavguskvvnzngh", model.ifTrueActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("mzbasxapcegtcdu", model.ifFalseActivities().get(0).name());
+ Assertions.assertEquals("tpkttjnney", model.ifFalseActivities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, model.ifFalseActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED,
- model.ifFalseActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("fqb", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifFalseActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("gh", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.ifFalseActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("djva", model.ifFalseActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("omq", model.ifFalseActivities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
IfConditionActivity model
- = new IfConditionActivity().withName("jjfne")
- .withDescription("qalwjcqbnvbzem")
+ = new IfConditionActivity().withName("isklotwnppstpq")
+ .withDescription("deawolhl")
.withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("cehlgryvkubfotgi")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("j").withValue("datajyx"),
- new UserProperty().withName("euqcbgbs").withValue("datagxak"),
- new UserProperty().withName("kbryolzbmdntajgg").withValue("datauyokctymsbhdi")))
- .withExpression(new Expression().withValue("pvbmbf"))
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("mhqylrsywiscoq")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("zmziiftjig")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
+ DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("hrtqnbdgc").withValue("dataicknsbbc"),
+ new UserProperty().withName("bqxwojvejxh").withValue("dataeolzftfyjcen")))
+ .withExpression(new Expression().withValue("ygzaya"))
.withIfTrueActivities(
Arrays
.asList(
- new Activity().withName("uamdydkdcvowasl")
- .withDescription("w")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ new Activity().withName("mlae")
+ .withDescription("hucxmybuqjpgbiya")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
.withDependsOn(
Arrays.asList(
- new ActivityDependency().withActivity("tiefxhaqqavhfd")
- .withDependencyConditions(Arrays
- .asList(DependencyCondition.FAILED, DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("inhpvbmbfi")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("daejn")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ new ActivityDependency().withActivity("aiwxlrphaddsxs")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(
- new UserProperty().withName("p").withValue("datakvok"),
- new UserProperty().withName("mere").withValue("datanoessuwkcnhdecxb"),
- new UserProperty()
- .withName("knfepixf")
- .withValue("dataojxbyxfxdnt"),
- new UserProperty().withName("ksbtige").withValue("datawaidqzf")))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("iavguskvvnzngh").withValue("dataoqe")))
.withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("rl")
- .withDescription("dkwibdri")
+ new Activity().withName("mere")
+ .withDescription("oessuwkcnhdecxbi")
.withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(
- Arrays
- .asList(
- new ActivityDependency().withActivity("lhecztmwwmybv")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.FAILED, DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("yduzzyx")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.FAILED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays
- .asList(new UserProperty().withName("kktlodsyyzmf").withValue("datagzljgrtfic"),
- new UserProperty().withName("ejmzbasxapcegtc").withValue("dataufet")))
- .withAdditionalProperties(mapOf("type", "Activity"))))
- .withIfFalseActivities(
- Arrays
- .asList(
- new Activity().withName("l")
- .withDescription("riimojozhd")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(
Arrays.asList(
- new ActivityDependency().withActivity("fqb")
+ new ActivityDependency().withActivity("fdojxbyxfxdnt")
.withDependencyConditions(Arrays
- .asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
+ .asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ntopfqguovqqrc")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ new ActivityDependency().withActivity("qlrmbgiaoxpfko")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("d")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ new ActivityDependency()
+ .withActivity("sjglpon")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(
- new UserProperty().withName("djva").withValue("dataae"),
- new UserProperty().withName("oqknz").withValue("datanvvkfbmrppjf"),
- new UserProperty().withName("eabgpw").withValue("datas")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("s")
- .withDescription("awolhlfffeznb")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(new ActivityDependency()
- .withActivity("ywiscoq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("ziif").withValue("datajigtqyzoc")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("cpwtj")
- .withDescription("uhrtqn")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency()
- .withActivity("kns")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.FAILED, DependencyCondition.COMPLETED,
- DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("eolzftfyjcen")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("i")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays
- .asList(new UserProperty().withName("jufljqz").withValue("dataixlzaavvuvhyerj")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("fqjweigywj")
- .withDescription("p")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(
- Arrays
- .asList(new ActivityDependency().withActivity("efdqnsuaoml")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SKIPPED, DependencyCondition.SKIPPED,
- DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
.withUserProperties(
- Arrays.asList(new UserProperty().withName("hkv").withValue("dataofxkelwvcyprpog"),
- new UserProperty().withName("qvuftkiyghcmpyki").withValue("dataochpzcgs"),
- new UserProperty().withName("pklfnst").withValue("datat")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ Arrays.asList(new UserProperty().withName("g").withValue("dataghohoxcontsrv")))
+ .withAdditionalProperties(mapOf("type", "Activity"))))
+ .withIfFalseActivities(Arrays.asList(new Activity().withName("mzbasxapcegtcdu")
+ .withDescription("tpkttjnney")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("gh")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("judpeedzowve")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("imojozhdcptxxb")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("dcrwoiqsrqebjgo")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("omq").withValue("databslwxcf"),
+ new UserProperty().withName("vedxyeba").withValue("datawnmnxppgfep"),
+ new UserProperty().withName("nedjvataeao").withValue("datakn"),
+ new UserProperty().withName("ynvv").withValue("datafbmrppjfceab")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(IfConditionActivity.class);
- Assertions.assertEquals("jjfne", model.name());
- Assertions.assertEquals("qalwjcqbnvbzem", model.description());
+ Assertions.assertEquals("isklotwnppstpq", model.name());
+ Assertions.assertEquals("deawolhl", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("cehlgryvkubfotgi", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("j", model.userProperties().get(0).name());
- Assertions.assertEquals("pvbmbf", model.expression().value());
- Assertions.assertEquals("uamdydkdcvowasl", model.ifTrueActivities().get(0).name());
- Assertions.assertEquals("w", model.ifTrueActivities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.ifTrueActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifTrueActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("tiefxhaqqavhfd", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED,
+ Assertions.assertEquals("mhqylrsywiscoq", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("hrtqnbdgc", model.userProperties().get(0).name());
+ Assertions.assertEquals("ygzaya", model.expression().value());
+ Assertions.assertEquals("mlae", model.ifTrueActivities().get(0).name());
+ Assertions.assertEquals("hucxmybuqjpgbiya", model.ifTrueActivities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.ifTrueActivities().get(0).state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.ifTrueActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("inhpvbmbfi", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.ifTrueActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("p", model.ifTrueActivities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("l", model.ifFalseActivities().get(0).name());
- Assertions.assertEquals("riimojozhd", model.ifFalseActivities().get(0).description());
+ Assertions.assertEquals("iavguskvvnzngh", model.ifTrueActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("mzbasxapcegtcdu", model.ifFalseActivities().get(0).name());
+ Assertions.assertEquals("tpkttjnney", model.ifFalseActivities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, model.ifFalseActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED,
- model.ifFalseActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("fqb", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifFalseActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("gh", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.ifFalseActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("djva", model.ifFalseActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("omq", model.ifFalseActivities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTypePropertiesTests.java
index 17510699d4ef..64f370255fb1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IfConditionActivityTypePropertiesTests.java
@@ -22,156 +22,188 @@ public final class IfConditionActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
IfConditionActivityTypeProperties model = BinaryData.fromString(
- "{\"expression\":{\"value\":\"mueuwpivsltlyq\"},\"ifTrueActivities\":[{\"type\":\"Activity\",\"name\":\"wndcjrdqcmsrzrcd\",\"description\":\"zgaoptwqfgqccon\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"dpmez\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Failed\",\"Completed\"],\"\":{\"ymqzmuinu\":\"datarafkrvvdwk\",\"djinuoslzrb\":\"datatgjgpc\",\"jgdvwamc\":\"datazfevwcjr\",\"svximqkuyflzx\":\"datacnevkfkmena\"}},{\"activity\":\"suuapktfvemwfwc\",\"dependencyConditions\":[\"Failed\"],\"\":{\"ykl\":\"datavywzh\"}},{\"activity\":\"cojxpkpsqk\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"zpgn\":\"dataybkhyqou\"}}],\"userProperties\":[{\"name\":\"snvtl\",\"value\":\"datanmydshgfdvws\"},{\"name\":\"cczyqnfsjnrfpz\",\"value\":\"datavaeojnskekhmo\"},{\"name\":\"vvrk\",\"value\":\"datasqfazsiiz\"},{\"name\":\"whax\",\"value\":\"datahaet\"}],\"\":{\"yajyiwvqlr\":\"datafjlismacac\",\"pjbja\":\"dataobvkg\"}},{\"type\":\"Activity\",\"name\":\"nky\",\"description\":\"j\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"hukuypyeo\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Completed\",\"Succeeded\"],\"\":{\"ldgbgua\":\"datakldtwrryclj\"}},{\"activity\":\"ilcdbudfwl\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"d\":\"datarfkslgpl\",\"tmu\":\"datacmkdhgpzqibqilc\",\"rjxaawentkok\":\"dataemex\"}},{\"activity\":\"djwp\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"nvtlbc\":\"dataqfwxicbvw\",\"wof\":\"datagrk\",\"xpeodbmuzpd\":\"dataeayowzp\",\"hi\":\"datathpsycasx\"}}],\"userProperties\":[{\"name\":\"miipffjgjm\",\"value\":\"datasnfpxrzqagmci\"},{\"name\":\"sqawiabyfzadeu\",\"value\":\"datatkfvdjgw\"}],\"\":{\"ulozdoi\":\"dataqgabrbsuxgnwuy\",\"iv\":\"datahrxjiw\",\"lau\":\"dataorqlkycwnb\",\"ah\":\"dataazyrisciokbvft\"}}],\"ifFalseActivities\":[{\"type\":\"Activity\",\"name\":\"llfkcro\",\"description\":\"imhdlmagd\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ndfpd\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\"],\"\":{\"tklojlgsbystznwj\":\"datasxxk\",\"ptvkjdowuzasd\":\"datasvllefliriq\",\"peeprmeb\":\"datatufmujadippdntun\",\"es\":\"dataxmaacrqrovbozj\"}},{\"activity\":\"rcxug\",\"dependencyConditions\":[\"Failed\"],\"\":{\"guelrasdrr\":\"datayvxdbuzdphogmrc\",\"njkbmfcrysvcab\":\"dataozzvygolz\",\"jmzqnbwnlo\":\"datak\",\"hrpv\":\"dataz\"}},{\"activity\":\"xutcoqclypbrnjor\",\"dependencyConditions\":[\"Failed\",\"Failed\"],\"\":{\"efhbzic\":\"dataxitppebuvxxloqr\",\"lzwvmwjuqchc\":\"datafdwgbgenwesxzu\"}}],\"userProperties\":[{\"name\":\"yscarjm\",\"value\":\"dataiewv\"},{\"name\":\"pyskhkvkwdtbvy\",\"value\":\"datalgkzbyxtprxtf\"},{\"name\":\"vng\",\"value\":\"datacsno\"},{\"name\":\"kglygeuo\",\"value\":\"datalywjvdr\"}],\"\":{\"nt\":\"datawzbrg\",\"n\":\"dataptrjtyhthfcpz\",\"g\":\"datavkhkubpojhdxcha\",\"vrnwxolfhiq\":\"dataw\"}},{\"type\":\"Activity\",\"name\":\"iulfxgzyr\",\"description\":\"uxlt\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"catozsodpbsqcw\",\"dependencyConditions\":[\"Failed\"],\"\":{\"ribmeuukk\":\"datahuixczycifdrjry\",\"jmnxlf\":\"datanwtucmh\",\"wzgb\":\"datam\",\"mrpbmxmxshfh\":\"databwmiap\"}},{\"activity\":\"p\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Failed\"],\"\":{\"vxytmoqnytucuzy\":\"datap\",\"e\":\"dataigdebsinsoybe\",\"mqjcagxrozcfcxk\":\"datarpouhlhlud\",\"kgepmnxvahqvc\":\"datahjxbteakdr\"}},{\"activity\":\"lphlkxdanlycc\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Skipped\"],\"\":{\"qzdedizdmwndnsg\":\"dataa\"}}],\"userProperties\":[{\"name\":\"pstwmdmwsf\",\"value\":\"datardyrxloxa\"},{\"name\":\"mxnmx\",\"value\":\"datamdlynlhsdtc\"},{\"name\":\"flevndldhwrf\",\"value\":\"dataflhwfrjyuhuthqdf\"},{\"name\":\"bizloyqjrkt\",\"value\":\"datadvuqve\"}],\"\":{\"relbzwxxsowd\":\"dataogesrmahszxcfbp\",\"nhqfae\":\"datauwvupn\"}},{\"type\":\"Activity\",\"name\":\"sboeapsraydlpu\",\"description\":\"makkwqrkaymdgzb\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"hrpamav\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Failed\"],\"\":{\"dw\":\"databbacixlirolaoo\"}},{\"activity\":\"jerm\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Skipped\"],\"\":{\"bexk\":\"dataoeqgkutkcczbu\"}}],\"userProperties\":[{\"name\":\"kjvsvywnzliqvq\",\"value\":\"datavfihnasaquk\"}],\"\":{\"qzf\":\"dataludfdhiori\",\"lywtgilhx\":\"datayqadtqwtsatjjfav\"}}]}")
+ "{\"expression\":{\"value\":\"x\"},\"ifTrueActivities\":[{\"type\":\"Activity\",\"name\":\"jgcdl\",\"description\":\"lpuurjxkp\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"uf\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Succeeded\",\"Completed\"],\"\":{\"yerjrc\":\"datazaavvuv\",\"spli\":\"datayxepllbneepfjib\",\"qpgncscw\":\"datafqjweigywj\"}},{\"activity\":\"efdqnsuaoml\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Skipped\",\"Completed\"],\"\":{\"mcrllecquo\":\"datanane\"}}],\"userProperties\":[{\"name\":\"hkv\",\"value\":\"dataofxkelwvcyprpog\"},{\"name\":\"qvuftkiyghcmpyki\",\"value\":\"dataochpzcgs\"},{\"name\":\"pklfnst\",\"value\":\"datat\"}],\"\":{\"esf\":\"datawotk\",\"d\":\"datarsgfpds\",\"fun\":\"dataivepmtt\",\"oczoiduk\":\"datakcji\"}},{\"type\":\"Activity\",\"name\":\"jjfne\",\"description\":\"qalwjcqbnvbzem\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"cehlgryvkubfotgi\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"fttsdtnqlggtrjzi\":\"datakirxy\",\"cinjej\":\"dataxzbu\",\"jzenagmhhmgtbqzf\":\"datainlysguladd\",\"qcprbwsndloldx\":\"datampgibmngb\"}}],\"userProperties\":[{\"name\":\"j\",\"value\":\"datajyx\"},{\"name\":\"euqcbgbs\",\"value\":\"datagxak\"},{\"name\":\"kbryolzbmdntajgg\",\"value\":\"datauyokctymsbhdi\"}],\"\":{\"pwwfei\":\"dataobsenxgkjfuwtluk\"}},{\"type\":\"Activity\",\"name\":\"mueuwpivsltlyq\",\"description\":\"pwndcjr\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"rcddlzgaopt\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Completed\",\"Succeeded\"],\"\":{\"optrudpm\":\"datand\",\"oflcilrafkrvvd\":\"datazl\"}}],\"userProperties\":[{\"name\":\"ymqzmuinu\",\"value\":\"datatgjgpc\"}],\"\":{\"slzrbzzfevwcjrb\":\"datainu\",\"wamcv\":\"datagd\"}},{\"type\":\"Activity\",\"name\":\"nevkfkm\",\"description\":\"awsvximqkuyflz\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ktfvemwfw\",\"dependencyConditions\":[\"Succeeded\",\"Failed\",\"Skipped\",\"Succeeded\"],\"\":{\"byklw\":\"datawz\",\"csnfeybk\":\"dataojxpkpsqk\"}},{\"activity\":\"yqo\",\"dependencyConditions\":[\"Succeeded\",\"Failed\",\"Failed\"],\"\":{\"lhnmydshgfdvwsh\":\"datadzsnv\",\"nfsjnrfpzlvae\":\"dataczy\",\"vvrk\":\"datajnskekhmo\"}},{\"activity\":\"sqfazsiiz\",\"dependencyConditions\":[\"Completed\"],\"\":{\"ismacacdyajy\":\"datajhaetyeafj\",\"bjavnkyqrjbzrz\":\"datawvqlrzobvkgfp\",\"aeabbxkldtw\":\"datahthukuypyeof\"}},{\"activity\":\"ryc\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"d\":\"datagbguaxil\",\"pxyrfkslg\":\"dataudfwlp\",\"ilcntmueemexa\":\"dataladqcmkdhgpzqib\",\"ntkokndjwpxe\":\"datajxaaw\"}}],\"userProperties\":[{\"name\":\"qfwxicbvw\",\"value\":\"datanvtlbc\"},{\"name\":\"grk\",\"value\":\"datawof\"},{\"name\":\"eayowzp\",\"value\":\"dataxpeodbmuzpd\"},{\"name\":\"thpsycasx\",\"value\":\"datahi\"}],\"\":{\"snfpxrzqagmci\":\"datamiipffjgjm\",\"tkfvdjgw\":\"datasqawiabyfzadeu\"}}],\"ifFalseActivities\":[{\"type\":\"Activity\",\"name\":\"qgabrbsuxgnwuy\",\"description\":\"lozdoilhrxjiwjiv\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"cwnbqlaubazyri\",\"dependencyConditions\":[\"Completed\",\"Succeeded\"],\"\":{\"sllfkcroviim\":\"datavftqahj\",\"w\":\"datadlmag\",\"endfpdoxtif\":\"datagfx\",\"tklojlgsbystznwj\":\"datasxxk\"}},{\"activity\":\"svllefliriq\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Failed\",\"Skipped\"],\"\":{\"ppdntunbpeepr\":\"datawuzasdztufmujad\",\"crqrovboz\":\"dataebvxma\",\"ug\":\"datacesmrc\",\"jxyv\":\"datat\"}},{\"activity\":\"dbuz\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Completed\"],\"\":{\"ozzvygolz\":\"datacmguelrasdrr\",\"k\":\"datanjkbmfcrysvcab\"}}],\"userProperties\":[{\"name\":\"zqn\",\"value\":\"datawnloozahrpv\"},{\"name\":\"xutcoqclypbrnjor\",\"value\":\"datacrgrjxit\"}],\"\":{\"rdefhbzic\":\"databuvxxlo\",\"lzwvmwjuqchc\":\"datafdwgbgenwesxzu\"}},{\"type\":\"Activity\",\"name\":\"otyscarjmhiewv\",\"description\":\"ysk\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"bvycl\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Succeeded\",\"Completed\"],\"\":{\"akglygeuoolywjvd\":\"datarxtfwvngwcsn\"}},{\"activity\":\"jlgwzbrggntqp\",\"dependencyConditions\":[\"Skipped\",\"Completed\"],\"\":{\"hv\":\"datathfcpzd\",\"pojhdxchaogaw\":\"datahku\",\"iulfxgzyr\":\"datavrnwxolfhiq\",\"tekixouhca\":\"dataqux\"}}],\"userProperties\":[{\"name\":\"sodpb\",\"value\":\"dataqcwjxatghui\"},{\"name\":\"czy\",\"value\":\"dataifdrjrywrib\"},{\"name\":\"euukko\",\"value\":\"datawtucmhpjmnxlfkm\"},{\"name\":\"wzgb\",\"value\":\"databwmiap\"}],\"\":{\"mxm\":\"datap\",\"fhbpbqimjnx\":\"datas\"}},{\"type\":\"Activity\",\"name\":\"fv\",\"description\":\"tmoqn\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"rigdebsins\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"rpouhlhlud\":\"datae\",\"hjxbteakdr\":\"datamqjcagxrozcfcxk\",\"lphlkxdanlycc\":\"datakgepmnxvahqvc\",\"d\":\"datamkpohgatq\"}},{\"activity\":\"dizd\",\"dependencyConditions\":[\"Failed\",\"Succeeded\",\"Completed\"],\"\":{\"yrxloxaym\":\"datagfzpstwmdmwsflr\",\"nlhsdtcgflevndl\":\"datanmxkmdl\"}},{\"activity\":\"hwrfcflhwfrjyuh\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Failed\",\"Failed\"],\"\":{\"uqve\":\"dataizloyqjrkted\",\"zxcf\":\"datajsogesrmah\",\"vupnd\":\"datapyrelbzwxxsowdnu\"}}],\"userProperties\":[{\"name\":\"faeisboeap\",\"value\":\"dataraydlpu\"},{\"name\":\"kmakkwqrkaym\",\"value\":\"datagzbkliokuwhrpam\"},{\"name\":\"vx\",\"value\":\"datarl\"}],\"\":{\"dw\":\"databbacixlirolaoo\"}},{\"type\":\"Activity\",\"name\":\"jerm\",\"description\":\"kikgp\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"kcczb\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"iqvqbvfihna\":\"datakwjhkjvsvywnz\"}}],\"userProperties\":[{\"name\":\"ukegkludfdh\",\"value\":\"dataorihqzfjyqadtq\"},{\"name\":\"tsa\",\"value\":\"datajjfa\"},{\"name\":\"plywtgilhxaa\",\"value\":\"datanuufenp\"}],\"\":{\"exqyroqklgvyce\":\"dataktnfeghcmxi\",\"twhyznlhak\":\"dataywuioi\"}}]}")
.toObject(IfConditionActivityTypeProperties.class);
- Assertions.assertEquals("mueuwpivsltlyq", model.expression().value());
- Assertions.assertEquals("wndcjrdqcmsrzrcd", model.ifTrueActivities().get(0).name());
- Assertions.assertEquals("zgaoptwqfgqccon", model.ifTrueActivities().get(0).description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.ifTrueActivities().get(0).state());
+ Assertions.assertEquals("x", model.expression().value());
+ Assertions.assertEquals("jgcdl", model.ifTrueActivities().get(0).name());
+ Assertions.assertEquals("lpuurjxkp", model.ifTrueActivities().get(0).description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.ifTrueActivities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifTrueActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("dpmez", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED,
+ Assertions.assertEquals("uf", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED,
model.ifTrueActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("snvtl", model.ifTrueActivities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("llfkcro", model.ifFalseActivities().get(0).name());
- Assertions.assertEquals("imhdlmagd", model.ifFalseActivities().get(0).description());
+ Assertions.assertEquals("hkv", model.ifTrueActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("qgabrbsuxgnwuy", model.ifFalseActivities().get(0).name());
+ Assertions.assertEquals("lozdoilhrxjiwjiv", model.ifFalseActivities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.ifFalseActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifFalseActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("ndfpd", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.ifFalseActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("cwnbqlaubazyri", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.ifFalseActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("yscarjm", model.ifFalseActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("zqn", model.ifFalseActivities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
IfConditionActivityTypeProperties model = new IfConditionActivityTypeProperties()
- .withExpression(new Expression().withValue("mueuwpivsltlyq"))
+ .withExpression(new Expression().withValue("x"))
.withIfTrueActivities(Arrays.asList(
- new Activity().withName("wndcjrdqcmsrzrcd")
- .withDescription("zgaoptwqfgqccon")
- .withState(ActivityState.ACTIVE)
+ new Activity().withName("jgcdl")
+ .withDescription("lpuurjxkp")
+ .withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("dpmez")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED, DependencyCondition.COMPLETED))
+ .withDependsOn(Arrays.asList(new ActivityDependency()
+ .withActivity("uf")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("suuapktfvemwfwc")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("cojxpkpsqk")
+ new ActivityDependency().withActivity("efdqnsuaoml")
.withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED,
+ DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf())))
.withUserProperties(
- Arrays.asList(new UserProperty().withName("snvtl").withValue("datanmydshgfdvws"),
- new UserProperty().withName("cczyqnfsjnrfpz").withValue("datavaeojnskekhmo"),
- new UserProperty()
- .withName("vvrk")
- .withValue("datasqfazsiiz"),
- new UserProperty().withName("whax").withValue("datahaet")))
+ Arrays.asList(new UserProperty().withName("hkv").withValue("dataofxkelwvcyprpog"),
+ new UserProperty().withName("qvuftkiyghcmpyki").withValue("dataochpzcgs"),
+ new UserProperty().withName("pklfnst").withValue("datat")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("jjfne")
+ .withDescription("qalwjcqbnvbzem")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("cehlgryvkubfotgi")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("j").withValue("datajyx"),
+ new UserProperty().withName("euqcbgbs").withValue("datagxak"),
+ new UserProperty().withName("kbryolzbmdntajgg").withValue("datauyokctymsbhdi")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("mueuwpivsltlyq")
+ .withDescription("pwndcjr")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("rcddlzgaopt")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("ymqzmuinu").withValue("datatgjgpc")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("nevkfkm")
+ .withDescription("awsvximqkuyflz")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("ktfvemwfw")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.FAILED, DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("yqo")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.FAILED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("sqfazsiiz")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ryc")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("qfwxicbvw").withValue("datanvtlbc"),
+ new UserProperty().withName("grk").withValue("datawof"),
+ new UserProperty().withName("eayowzp").withValue("dataxpeodbmuzpd"),
+ new UserProperty().withName("thpsycasx").withValue("datahi")))
+ .withAdditionalProperties(mapOf("type", "Activity"))))
+ .withIfFalseActivities(Arrays.asList(
+ new Activity().withName("qgabrbsuxgnwuy")
+ .withDescription("lozdoilhrxjiwjiv")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("cwnbqlaubazyri")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("svllefliriq")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.FAILED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("dbuz")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("zqn").withValue("datawnloozahrpv"),
+ new UserProperty().withName("xutcoqclypbrnjor").withValue("datacrgrjxit")))
.withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("nky")
- .withDescription("j")
+ new Activity().withName("otyscarjmhiewv")
+ .withDescription("ysk")
.withState(ActivityState.ACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("hukuypyeo")
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("bvycl")
.withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.SKIPPED, DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ilcdbudfwl")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ new ActivityDependency().withActivity("jlgwzbrggntqp")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("sodpb").withValue("dataqcwjxatghui"),
+ new UserProperty().withName("czy").withValue("dataifdrjrywrib"),
+ new UserProperty().withName("euukko").withValue("datawtucmhpjmnxlfkm"),
+ new UserProperty().withName("wzgb").withValue("databwmiap")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("fv")
+ .withDescription("tmoqn")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("rigdebsins")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("djwp")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ new ActivityDependency().withActivity("dizd")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("hwrfcflhwfrjyuh")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.COMPLETED, DependencyCondition.FAILED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf())))
.withUserProperties(
- Arrays.asList(new UserProperty().withName("miipffjgjm").withValue("datasnfpxrzqagmci"),
- new UserProperty().withName("sqawiabyfzadeu").withValue("datatkfvdjgw")))
- .withAdditionalProperties(mapOf("type", "Activity"))))
- .withIfFalseActivities(
- Arrays
- .asList(
- new Activity().withName("llfkcro")
- .withDescription("imhdlmagd")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(
- Arrays
- .asList(
- new ActivityDependency().withActivity("ndfpd")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("rcxug")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("xutcoqclypbrnjor")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("yscarjm").withValue("dataiewv"),
- new UserProperty().withName("pyskhkvkwdtbvy").withValue("datalgkzbyxtprxtf"),
- new UserProperty().withName("vng").withValue("datacsno"),
- new UserProperty().withName("kglygeuo").withValue("datalywjvdr")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("iulfxgzyr")
- .withDescription("uxlt")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("catozsodpbsqcw")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("p")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("lphlkxdanlycc")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(
- new UserProperty().withName("pstwmdmwsf").withValue("datardyrxloxa"),
- new UserProperty().withName("mxnmx").withValue("datamdlynlhsdtc"),
- new UserProperty().withName("flevndldhwrf").withValue("dataflhwfrjyuhuthqdf"),
- new UserProperty().withName("bizloyqjrkt").withValue("datadvuqve")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("sboeapsraydlpu")
- .withDescription("makkwqrkaymdgzb")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("hrpamav")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("jerm")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.FAILED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays
- .asList(new UserProperty().withName("kjvsvywnzliqvq").withValue("datavfihnasaquk")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ Arrays.asList(new UserProperty().withName("faeisboeap").withValue("dataraydlpu"),
+ new UserProperty().withName("kmakkwqrkaym").withValue("datagzbkliokuwhrpam"),
+ new UserProperty().withName("vx").withValue("datarl")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("jerm")
+ .withDescription("kikgp")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("kcczb")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("ukegkludfdh").withValue("dataorihqzfjyqadtq"),
+ new UserProperty().withName("tsa").withValue("datajjfa"),
+ new UserProperty().withName("plywtgilhxaa").withValue("datanuufenp")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(IfConditionActivityTypeProperties.class);
- Assertions.assertEquals("mueuwpivsltlyq", model.expression().value());
- Assertions.assertEquals("wndcjrdqcmsrzrcd", model.ifTrueActivities().get(0).name());
- Assertions.assertEquals("zgaoptwqfgqccon", model.ifTrueActivities().get(0).description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.ifTrueActivities().get(0).state());
+ Assertions.assertEquals("x", model.expression().value());
+ Assertions.assertEquals("jgcdl", model.ifTrueActivities().get(0).name());
+ Assertions.assertEquals("lpuurjxkp", model.ifTrueActivities().get(0).description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.ifTrueActivities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifTrueActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("dpmez", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.COMPLETED,
+ Assertions.assertEquals("uf", model.ifTrueActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED,
model.ifTrueActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("snvtl", model.ifTrueActivities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("llfkcro", model.ifFalseActivities().get(0).name());
- Assertions.assertEquals("imhdlmagd", model.ifFalseActivities().get(0).description());
+ Assertions.assertEquals("hkv", model.ifTrueActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("qgabrbsuxgnwuy", model.ifFalseActivities().get(0).name());
+ Assertions.assertEquals("lozdoilhrxjiwjiv", model.ifFalseActivities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.ifFalseActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.ifFalseActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("ndfpd", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.ifFalseActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("cwnbqlaubazyri", model.ifFalseActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.ifFalseActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("yscarjm", model.ifFalseActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("zqn", model.ifFalseActivities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaDatasetTypePropertiesTests.java
index aee646361d27..749530eaaf33 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaDatasetTypePropertiesTests.java
@@ -10,16 +10,16 @@
public final class ImpalaDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- ImpalaDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"datamby\",\"table\":\"datavwnbu\",\"schema\":\"dataodtevzshqykebmps\"}")
- .toObject(ImpalaDatasetTypeProperties.class);
+ ImpalaDatasetTypeProperties model
+ = BinaryData.fromString("{\"tableName\":\"datautfz\",\"table\":\"datarcdzytrtf\",\"schema\":\"datapkdx\"}")
+ .toObject(ImpalaDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ImpalaDatasetTypeProperties model = new ImpalaDatasetTypeProperties().withTableName("datamby")
- .withTable("datavwnbu")
- .withSchema("dataodtevzshqykebmps");
+ ImpalaDatasetTypeProperties model = new ImpalaDatasetTypeProperties().withTableName("datautfz")
+ .withTable("datarcdzytrtf")
+ .withSchema("datapkdx");
model = BinaryData.fromObject(model).toObject(ImpalaDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaObjectDatasetTests.java
index 45d384eaefe0..4fe22834d4e9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaObjectDatasetTests.java
@@ -19,35 +19,33 @@ public final class ImpalaObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ImpalaObjectDataset model = BinaryData.fromString(
- "{\"type\":\"ImpalaObject\",\"typeProperties\":{\"tableName\":\"dataxiefcorzbidaeb\",\"table\":\"datanicewd\",\"schema\":\"datajwiylciobb\"},\"description\":\"ws\",\"structure\":\"dataeqx\",\"schema\":\"datacuuuexsmnteevfg\",\"linkedServiceName\":{\"referenceName\":\"xfezraqsddko\",\"parameters\":{\"w\":\"dataxqfkyrxgmzzeg\",\"fegaok\":\"datazfss\"}},\"parameters\":{\"fyuklxkelmz\":{\"type\":\"String\",\"defaultValue\":\"datara\"},\"gsingmhpavsfg\":{\"type\":\"SecureString\",\"defaultValue\":\"databwhuecx\"},\"klj\":{\"type\":\"Float\",\"defaultValue\":\"dataqrwwbdrwro\"}},\"annotations\":[\"dataqhqq\",\"dataarkyulfamea\",\"datasjqenh\"],\"folder\":{\"name\":\"azvgeytlplslfcv\"},\"\":{\"jocrhnxzmfvmw\":\"datasuowtolkyqf\",\"rawwhyxf\":\"datanrtc\"}}")
+ "{\"type\":\"ImpalaObject\",\"typeProperties\":{\"tableName\":\"dataznlf\",\"table\":\"datafzx\",\"schema\":\"dataz\"},\"description\":\"ugtkxncwdytnlr\",\"structure\":\"datamwbe\",\"schema\":\"dataww\",\"linkedServiceName\":{\"referenceName\":\"vnhwwkrmqe\",\"parameters\":{\"gnjxiakgyjm\":\"datahafqfudfyziruq\"}},\"parameters\":{\"c\":{\"type\":\"Array\",\"defaultValue\":\"dataikyluyugmbr\"}},\"annotations\":[\"dataoxtv\",\"datac\"],\"folder\":{\"name\":\"yhmmglvnbenkps\"},\"\":{\"nkxvcptf\":\"dataky\",\"gazhlrdxpc\":\"datafbhnkxasomaf\"}}")
.toObject(ImpalaObjectDataset.class);
- Assertions.assertEquals("ws", model.description());
- Assertions.assertEquals("xfezraqsddko", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("fyuklxkelmz").type());
- Assertions.assertEquals("azvgeytlplslfcv", model.folder().name());
+ Assertions.assertEquals("ugtkxncwdytnlr", model.description());
+ Assertions.assertEquals("vnhwwkrmqe", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("c").type());
+ Assertions.assertEquals("yhmmglvnbenkps", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ImpalaObjectDataset model = new ImpalaObjectDataset().withDescription("ws")
- .withStructure("dataeqx")
- .withSchema("datacuuuexsmnteevfg")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xfezraqsddko")
- .withParameters(mapOf("w", "dataxqfkyrxgmzzeg", "fegaok", "datazfss")))
- .withParameters(mapOf("fyuklxkelmz",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datara"), "gsingmhpavsfg",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("databwhuecx"),
- "klj", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqrwwbdrwro")))
- .withAnnotations(Arrays.asList("dataqhqq", "dataarkyulfamea", "datasjqenh"))
- .withFolder(new DatasetFolder().withName("azvgeytlplslfcv"))
- .withTableName("dataxiefcorzbidaeb")
- .withTable("datanicewd")
- .withSchemaTypePropertiesSchema("datajwiylciobb");
+ ImpalaObjectDataset model = new ImpalaObjectDataset().withDescription("ugtkxncwdytnlr")
+ .withStructure("datamwbe")
+ .withSchema("dataww")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vnhwwkrmqe")
+ .withParameters(mapOf("gnjxiakgyjm", "datahafqfudfyziruq")))
+ .withParameters(mapOf("c",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataikyluyugmbr")))
+ .withAnnotations(Arrays.asList("dataoxtv", "datac"))
+ .withFolder(new DatasetFolder().withName("yhmmglvnbenkps"))
+ .withTableName("dataznlf")
+ .withTable("datafzx")
+ .withSchemaTypePropertiesSchema("dataz");
model = BinaryData.fromObject(model).toObject(ImpalaObjectDataset.class);
- Assertions.assertEquals("ws", model.description());
- Assertions.assertEquals("xfezraqsddko", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("fyuklxkelmz").type());
- Assertions.assertEquals("azvgeytlplslfcv", model.folder().name());
+ Assertions.assertEquals("ugtkxncwdytnlr", model.description());
+ Assertions.assertEquals("vnhwwkrmqe", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("c").type());
+ Assertions.assertEquals("yhmmglvnbenkps", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaSourceTests.java
index fb5229a7d315..bb3ea463c962 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImpalaSourceTests.java
@@ -11,19 +11,19 @@ public final class ImpalaSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ImpalaSource model = BinaryData.fromString(
- "{\"type\":\"ImpalaSource\",\"query\":\"dataqaptqyrnlyuyopww\",\"queryTimeout\":\"dataoubwbssvfzjjf\",\"additionalColumns\":\"dataxeosyl\",\"sourceRetryCount\":\"datappqjujbqrfw\",\"sourceRetryWait\":\"datawvpnbgyxo\",\"maxConcurrentConnections\":\"datakzeaiaycauvlfsc\",\"disableMetricsCollection\":\"dataqpzqivfgemvuicxw\",\"\":{\"atjm\":\"dataydlvfnucgwflj\"}}")
+ "{\"type\":\"ImpalaSource\",\"query\":\"dataht\",\"queryTimeout\":\"datauiptudw\",\"additionalColumns\":\"datasrpsjkqfabju\",\"sourceRetryCount\":\"datats\",\"sourceRetryWait\":\"dataupcio\",\"maxConcurrentConnections\":\"datarjdeyfnqanbadkzp\",\"disableMetricsCollection\":\"datatuplpkjexq\",\"\":{\"goeftrbxomaa\":\"datazlal\",\"gvjmllzykalbaumm\":\"datavarfqverxelquqze\",\"r\":\"datadwqiucpj\",\"ftt\":\"databssjtjwzelx\"}}")
.toObject(ImpalaSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ImpalaSource model = new ImpalaSource().withSourceRetryCount("datappqjujbqrfw")
- .withSourceRetryWait("datawvpnbgyxo")
- .withMaxConcurrentConnections("datakzeaiaycauvlfsc")
- .withDisableMetricsCollection("dataqpzqivfgemvuicxw")
- .withQueryTimeout("dataoubwbssvfzjjf")
- .withAdditionalColumns("dataxeosyl")
- .withQuery("dataqaptqyrnlyuyopww");
+ ImpalaSource model = new ImpalaSource().withSourceRetryCount("datats")
+ .withSourceRetryWait("dataupcio")
+ .withMaxConcurrentConnections("datarjdeyfnqanbadkzp")
+ .withDisableMetricsCollection("datatuplpkjexq")
+ .withQueryTimeout("datauiptudw")
+ .withAdditionalColumns("datasrpsjkqfabju")
+ .withQuery("dataht");
model = BinaryData.fromObject(model).toObject(ImpalaSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImportSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImportSettingsTests.java
index 152d3a4e3a03..9dd7be03a4a8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImportSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ImportSettingsTests.java
@@ -12,9 +12,9 @@
public final class ImportSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- ImportSettings model = BinaryData.fromString(
- "{\"type\":\"ImportSettings\",\"\":{\"jmphyacd\":\"dataevpdbirh\",\"hljtkuyvytfuq\":\"datajmpnvgkxs\",\"kf\":\"datastqbxpyfawkjei\"}}")
- .toObject(ImportSettings.class);
+ ImportSettings model
+ = BinaryData.fromString("{\"type\":\"ImportSettings\",\"\":{\"ngca\":\"databemxmuygmrenr\"}}")
+ .toObject(ImportSettings.class);
}
@org.junit.jupiter.api.Test
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSinkTests.java
index de4ee3b77c73..6fe9f489e2c4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSinkTests.java
@@ -11,19 +11,19 @@ public final class InformixSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
InformixSink model = BinaryData.fromString(
- "{\"type\":\"InformixSink\",\"preCopyScript\":\"datapddletjiud\",\"writeBatchSize\":\"dataktsgcypjlmsta\",\"writeBatchTimeout\":\"datarebecxuu\",\"sinkRetryCount\":\"dataukluukxejamyc\",\"sinkRetryWait\":\"datawrv\",\"maxConcurrentConnections\":\"datajxkttx\",\"disableMetricsCollection\":\"databedvvmrtnmgabfz\",\"\":{\"bpmpl\":\"dataihylzwzh\",\"knbnamtv\":\"datath\",\"fx\":\"dataoaac\",\"rvtuxv\":\"datansvjctytyt\"}}")
+ "{\"type\":\"InformixSink\",\"preCopyScript\":\"dataxvjjwlwysrs\",\"writeBatchSize\":\"datahciazwebts\",\"writeBatchTimeout\":\"dataqkanuxjud\",\"sinkRetryCount\":\"datazodnxlcdgkc\",\"sinkRetryWait\":\"dataancjlkrskzw\",\"maxConcurrentConnections\":\"databafqzihmvw\",\"disableMetricsCollection\":\"datajwvqiahoqjz\",\"\":{\"hgwzbystwuuwe\":\"datawdlrtcfulmz\",\"qichzcajity\":\"datantjssjbpnatpym\"}}")
.toObject(InformixSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- InformixSink model = new InformixSink().withWriteBatchSize("dataktsgcypjlmsta")
- .withWriteBatchTimeout("datarebecxuu")
- .withSinkRetryCount("dataukluukxejamyc")
- .withSinkRetryWait("datawrv")
- .withMaxConcurrentConnections("datajxkttx")
- .withDisableMetricsCollection("databedvvmrtnmgabfz")
- .withPreCopyScript("datapddletjiud");
+ InformixSink model = new InformixSink().withWriteBatchSize("datahciazwebts")
+ .withWriteBatchTimeout("dataqkanuxjud")
+ .withSinkRetryCount("datazodnxlcdgkc")
+ .withSinkRetryWait("dataancjlkrskzw")
+ .withMaxConcurrentConnections("databafqzihmvw")
+ .withDisableMetricsCollection("datajwvqiahoqjz")
+ .withPreCopyScript("dataxvjjwlwysrs");
model = BinaryData.fromObject(model).toObject(InformixSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSourceTests.java
index 8a1a03ee4c41..d85c994fd05f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixSourceTests.java
@@ -11,19 +11,19 @@ public final class InformixSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
InformixSource model = BinaryData.fromString(
- "{\"type\":\"InformixSource\",\"query\":\"datakpwltozxdzold\",\"queryTimeout\":\"datafnpn\",\"additionalColumns\":\"dataterjjuzarege\",\"sourceRetryCount\":\"dataozpudal\",\"sourceRetryWait\":\"datagdhdtt\",\"maxConcurrentConnections\":\"datakeculxvkuxvccpda\",\"disableMetricsCollection\":\"dataasi\",\"\":{\"ejh\":\"datayvvg\",\"ybneuzueikadhusg\":\"dataoswjwbhtawbc\"}}")
+ "{\"type\":\"InformixSource\",\"query\":\"datavjutckfhmdcvlb\",\"queryTimeout\":\"dataezvujpbmz\",\"additionalColumns\":\"datalgm\",\"sourceRetryCount\":\"dataxwkkbnhmdtj\",\"sourceRetryWait\":\"datapfoispchhvvmvs\",\"maxConcurrentConnections\":\"datayqdhaz\",\"disableMetricsCollection\":\"dataug\",\"\":{\"ubobqqnwhcmvdow\":\"dataovozyepkrncjrqhu\"}}")
.toObject(InformixSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- InformixSource model = new InformixSource().withSourceRetryCount("dataozpudal")
- .withSourceRetryWait("datagdhdtt")
- .withMaxConcurrentConnections("datakeculxvkuxvccpda")
- .withDisableMetricsCollection("dataasi")
- .withQueryTimeout("datafnpn")
- .withAdditionalColumns("dataterjjuzarege")
- .withQuery("datakpwltozxdzold");
+ InformixSource model = new InformixSource().withSourceRetryCount("dataxwkkbnhmdtj")
+ .withSourceRetryWait("datapfoispchhvvmvs")
+ .withMaxConcurrentConnections("datayqdhaz")
+ .withDisableMetricsCollection("dataug")
+ .withQueryTimeout("dataezvujpbmz")
+ .withAdditionalColumns("datalgm")
+ .withQuery("datavjutckfhmdcvlb");
model = BinaryData.fromObject(model).toObject(InformixSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTests.java
index f1b23f977eae..5d2b6f3571da 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTests.java
@@ -19,35 +19,35 @@ public final class InformixTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
InformixTableDataset model = BinaryData.fromString(
- "{\"type\":\"InformixTable\",\"typeProperties\":{\"tableName\":\"dataspth\"},\"description\":\"fmwtblgm\",\"structure\":\"datakqoikxiefwln\",\"schema\":\"datakffcnuestbsl\",\"linkedServiceName\":{\"referenceName\":\"e\",\"parameters\":{\"ikjiytehhxt\":\"dataccote\",\"n\":\"dataxqdwbymuq\"}},\"parameters\":{\"pek\":{\"type\":\"Bool\",\"defaultValue\":\"dataorctyse\"},\"tzcvimmwckoz\":{\"type\":\"Float\",\"defaultValue\":\"databyh\"},\"xup\":{\"type\":\"String\",\"defaultValue\":\"dataymtrts\"},\"rfrjschjxncqzahg\":{\"type\":\"String\",\"defaultValue\":\"datackjbcbkg\"}},\"annotations\":[\"datagdobimor\"],\"folder\":{\"name\":\"xosgihtrxue\"},\"\":{\"znjqswshe\":\"dataxqfg\"}}")
+ "{\"type\":\"InformixTable\",\"typeProperties\":{\"tableName\":\"datazizyxdu\"},\"description\":\"nqzbrq\",\"structure\":\"datak\",\"schema\":\"datackviyjucamns\",\"linkedServiceName\":{\"referenceName\":\"qoitwhmucjiu\",\"parameters\":{\"elyqdvpqfbxg\":\"datayvehyk\"}},\"parameters\":{\"yw\":{\"type\":\"Array\",\"defaultValue\":\"datasdmtxqlefnoh\"},\"ey\":{\"type\":\"String\",\"defaultValue\":\"datapkyll\"},\"vcneqswxhqhgk\":{\"type\":\"Int\",\"defaultValue\":\"datapwdmsfwtwrsv\"},\"ncpmyh\":{\"type\":\"Array\",\"defaultValue\":\"datazvulqevv\"}},\"annotations\":[\"datadmvghcmi\",\"datamlwkfefbcyj\",\"datatalqee\",\"dataudfyimooaez\"],\"folder\":{\"name\":\"ms\"},\"\":{\"zbaeeek\":\"datahlqwbywa\"}}")
.toObject(InformixTableDataset.class);
- Assertions.assertEquals("fmwtblgm", model.description());
- Assertions.assertEquals("e", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("pek").type());
- Assertions.assertEquals("xosgihtrxue", model.folder().name());
+ Assertions.assertEquals("nqzbrq", model.description());
+ Assertions.assertEquals("qoitwhmucjiu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("yw").type());
+ Assertions.assertEquals("ms", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- InformixTableDataset model = new InformixTableDataset().withDescription("fmwtblgm")
- .withStructure("datakqoikxiefwln")
- .withSchema("datakffcnuestbsl")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("e")
- .withParameters(mapOf("ikjiytehhxt", "dataccote", "n", "dataxqdwbymuq")))
- .withParameters(mapOf("pek",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataorctyse"),
- "tzcvimmwckoz", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("databyh"),
- "xup", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataymtrts"),
- "rfrjschjxncqzahg",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datackjbcbkg")))
- .withAnnotations(Arrays.asList("datagdobimor"))
- .withFolder(new DatasetFolder().withName("xosgihtrxue"))
- .withTableName("dataspth");
+ InformixTableDataset model = new InformixTableDataset().withDescription("nqzbrq")
+ .withStructure("datak")
+ .withSchema("datackviyjucamns")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qoitwhmucjiu")
+ .withParameters(mapOf("elyqdvpqfbxg", "datayvehyk")))
+ .withParameters(mapOf("yw",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datasdmtxqlefnoh"), "ey",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datapkyll"),
+ "vcneqswxhqhgk",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datapwdmsfwtwrsv"), "ncpmyh",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datazvulqevv")))
+ .withAnnotations(Arrays.asList("datadmvghcmi", "datamlwkfefbcyj", "datatalqee", "dataudfyimooaez"))
+ .withFolder(new DatasetFolder().withName("ms"))
+ .withTableName("datazizyxdu");
model = BinaryData.fromObject(model).toObject(InformixTableDataset.class);
- Assertions.assertEquals("fmwtblgm", model.description());
- Assertions.assertEquals("e", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("pek").type());
- Assertions.assertEquals("xosgihtrxue", model.folder().name());
+ Assertions.assertEquals("nqzbrq", model.description());
+ Assertions.assertEquals("qoitwhmucjiu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("yw").type());
+ Assertions.assertEquals("ms", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTypePropertiesTests.java
index 20bb00cf3fc4..b4fed1136467 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/InformixTableDatasetTypePropertiesTests.java
@@ -10,14 +10,13 @@
public final class InformixTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- InformixTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datacsqosecxlngo\"}")
- .toObject(InformixTableDatasetTypeProperties.class);
+ InformixTableDatasetTypeProperties model
+ = BinaryData.fromString("{\"tableName\":\"datat\"}").toObject(InformixTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- InformixTableDatasetTypeProperties model
- = new InformixTableDatasetTypeProperties().withTableName("datacsqosecxlngo");
+ InformixTableDatasetTypeProperties model = new InformixTableDatasetTypeProperties().withTableName("datat");
model = BinaryData.fromObject(model).toObject(InformixTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeComputePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeComputePropertiesTests.java
index 5739d2fd925e..e4b1c32cf7b2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeComputePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeComputePropertiesTests.java
@@ -21,81 +21,80 @@ public final class IntegrationRuntimeComputePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
IntegrationRuntimeComputeProperties model = BinaryData.fromString(
- "{\"location\":\"zxxzndwtomin\",\"nodeSize\":\"f\",\"numberOfNodes\":1479856776,\"maxParallelExecutionsPerNode\":2091496981,\"dataFlowProperties\":{\"computeType\":\"General\",\"coreCount\":610534246,\"timeToLive\":513393962,\"cleanup\":false,\"customProperties\":[{\"name\":\"q\",\"value\":\"t\"},{\"name\":\"uzc\",\"value\":\"lirybytcaqp\"},{\"name\":\"hlc\",\"value\":\"rvxyyh\"}],\"\":{\"eqiwduukaamimkj\":\"datasztqfrpan\"}},\"vNetProperties\":{\"vNetId\":\"ysjdfxvksijr\",\"subnet\":\"yindex\",\"publicIPs\":[\"vuyxuu\",\"zea\"],\"subnetId\":\"atopdtphvj\",\"\":{\"ngqyiyjxzxbtht\":\"datazy\",\"cve\":\"datayzpuonrmdlkoab\"}},\"copyComputeScaleProperties\":{\"dataIntegrationUnit\":1097849397,\"timeToLive\":2091236479,\"\":{\"yuyutkbxr\":\"dataqshsasm\"}},\"pipelineExternalComputeScaleProperties\":{\"timeToLive\":670066514,\"numberOfPipelineNodes\":2055140017,\"numberOfExternalNodes\":1136227748,\"\":{\"dfeemxiurpf\":\"datauuihkybgkyncyzj\"}},\"\":{\"o\":\"datapmwdzajpcroxp\"}}")
+ "{\"location\":\"c\",\"nodeSize\":\"xevlt\",\"numberOfNodes\":1736990485,\"maxParallelExecutionsPerNode\":1753770104,\"dataFlowProperties\":{\"computeType\":\"General\",\"coreCount\":2045958196,\"timeToLive\":492843137,\"cleanup\":true,\"customProperties\":[{\"name\":\"fmftwr\",\"value\":\"mriipzgfofuad\"},{\"name\":\"qneaqkgttbarg\",\"value\":\"ynqlsnr\"}],\"\":{\"yxhsppv\":\"dataoyvgjjp\",\"geqeapaseq\":\"datasduouoqtenqsomu\"}},\"vNetProperties\":{\"vNetId\":\"ypfreuwvzhn\",\"subnet\":\"vtoiqofzttqg\",\"publicIPs\":[\"w\",\"oxzuhellit\",\"qv\",\"ivrsgqbmolxeom\"],\"subnetId\":\"zvtvxxfs\",\"\":{\"edybkbgdwbmi\":\"dataacgihnalpc\",\"i\":\"datazikatywedb\"}},\"copyComputeScaleProperties\":{\"dataIntegrationUnit\":785813210,\"timeToLive\":95344421,\"\":{\"pave\":\"databhxncszd\"}},\"pipelineExternalComputeScaleProperties\":{\"timeToLive\":862321993,\"numberOfPipelineNodes\":922478953,\"numberOfExternalNodes\":1537232280,\"\":{\"erffhgvcym\":\"datadltniuii\",\"eudbobmol\":\"datadoeilhggaj\",\"ua\":\"datairchhwlzihvcc\"}},\"\":{\"toiwfsz\":\"dataipdjxyotgvraxh\",\"etsluqfgk\":\"datarlkosjwr\",\"imioixviobuwbnge\":\"datad\",\"gqamhbmggnqxnex\":\"datawhdq\"}}")
.toObject(IntegrationRuntimeComputeProperties.class);
- Assertions.assertEquals("zxxzndwtomin", model.location());
- Assertions.assertEquals("f", model.nodeSize());
- Assertions.assertEquals(1479856776, model.numberOfNodes());
- Assertions.assertEquals(2091496981, model.maxParallelExecutionsPerNode());
+ Assertions.assertEquals("c", model.location());
+ Assertions.assertEquals("xevlt", model.nodeSize());
+ Assertions.assertEquals(1736990485, model.numberOfNodes());
+ Assertions.assertEquals(1753770104, model.maxParallelExecutionsPerNode());
Assertions.assertEquals(DataFlowComputeType.GENERAL, model.dataFlowProperties().computeType());
- Assertions.assertEquals(610534246, model.dataFlowProperties().coreCount());
- Assertions.assertEquals(513393962, model.dataFlowProperties().timeToLive());
- Assertions.assertEquals(false, model.dataFlowProperties().cleanup());
- Assertions.assertEquals("q", model.dataFlowProperties().customProperties().get(0).name());
- Assertions.assertEquals("t", model.dataFlowProperties().customProperties().get(0).value());
- Assertions.assertEquals("ysjdfxvksijr", model.vNetProperties().vNetId());
- Assertions.assertEquals("yindex", model.vNetProperties().subnet());
- Assertions.assertEquals("vuyxuu", model.vNetProperties().publicIPs().get(0));
- Assertions.assertEquals("atopdtphvj", model.vNetProperties().subnetId());
- Assertions.assertEquals(1097849397, model.copyComputeScaleProperties().dataIntegrationUnit());
- Assertions.assertEquals(2091236479, model.copyComputeScaleProperties().timeToLive());
- Assertions.assertEquals(670066514, model.pipelineExternalComputeScaleProperties().timeToLive());
- Assertions.assertEquals(2055140017, model.pipelineExternalComputeScaleProperties().numberOfPipelineNodes());
- Assertions.assertEquals(1136227748, model.pipelineExternalComputeScaleProperties().numberOfExternalNodes());
+ Assertions.assertEquals(2045958196, model.dataFlowProperties().coreCount());
+ Assertions.assertEquals(492843137, model.dataFlowProperties().timeToLive());
+ Assertions.assertEquals(true, model.dataFlowProperties().cleanup());
+ Assertions.assertEquals("fmftwr", model.dataFlowProperties().customProperties().get(0).name());
+ Assertions.assertEquals("mriipzgfofuad", model.dataFlowProperties().customProperties().get(0).value());
+ Assertions.assertEquals("ypfreuwvzhn", model.vNetProperties().vNetId());
+ Assertions.assertEquals("vtoiqofzttqg", model.vNetProperties().subnet());
+ Assertions.assertEquals("w", model.vNetProperties().publicIPs().get(0));
+ Assertions.assertEquals("zvtvxxfs", model.vNetProperties().subnetId());
+ Assertions.assertEquals(785813210, model.copyComputeScaleProperties().dataIntegrationUnit());
+ Assertions.assertEquals(95344421, model.copyComputeScaleProperties().timeToLive());
+ Assertions.assertEquals(862321993, model.pipelineExternalComputeScaleProperties().timeToLive());
+ Assertions.assertEquals(922478953, model.pipelineExternalComputeScaleProperties().numberOfPipelineNodes());
+ Assertions.assertEquals(1537232280, model.pipelineExternalComputeScaleProperties().numberOfExternalNodes());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- IntegrationRuntimeComputeProperties model = new IntegrationRuntimeComputeProperties()
- .withLocation("zxxzndwtomin")
- .withNodeSize("f")
- .withNumberOfNodes(1479856776)
- .withMaxParallelExecutionsPerNode(2091496981)
- .withDataFlowProperties(new IntegrationRuntimeDataFlowProperties()
- .withComputeType(DataFlowComputeType.GENERAL)
- .withCoreCount(610534246)
- .withTimeToLive(513393962)
- .withCleanup(false)
- .withCustomProperties(Arrays.asList(
- new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("q").withValue("t"),
- new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("uzc")
- .withValue("lirybytcaqp"),
- new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("hlc").withValue("rvxyyh")))
- .withAdditionalProperties(mapOf()))
- .withVNetProperties(new IntegrationRuntimeVNetProperties().withVNetId("ysjdfxvksijr")
- .withSubnet("yindex")
- .withPublicIPs(Arrays.asList("vuyxuu", "zea"))
- .withSubnetId("atopdtphvj")
+ IntegrationRuntimeComputeProperties model = new IntegrationRuntimeComputeProperties().withLocation("c")
+ .withNodeSize("xevlt")
+ .withNumberOfNodes(1736990485)
+ .withMaxParallelExecutionsPerNode(1753770104)
+ .withDataFlowProperties(
+ new IntegrationRuntimeDataFlowProperties().withComputeType(DataFlowComputeType.GENERAL)
+ .withCoreCount(2045958196)
+ .withTimeToLive(492843137)
+ .withCleanup(true)
+ .withCustomProperties(Arrays.asList(
+ new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("fmftwr")
+ .withValue("mriipzgfofuad"),
+ new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("qneaqkgttbarg")
+ .withValue("ynqlsnr")))
+ .withAdditionalProperties(mapOf()))
+ .withVNetProperties(new IntegrationRuntimeVNetProperties().withVNetId("ypfreuwvzhn")
+ .withSubnet("vtoiqofzttqg")
+ .withPublicIPs(Arrays.asList("w", "oxzuhellit", "qv", "ivrsgqbmolxeom"))
+ .withSubnetId("zvtvxxfs")
.withAdditionalProperties(mapOf()))
- .withCopyComputeScaleProperties(new CopyComputeScaleProperties().withDataIntegrationUnit(1097849397)
- .withTimeToLive(2091236479)
+ .withCopyComputeScaleProperties(new CopyComputeScaleProperties().withDataIntegrationUnit(785813210)
+ .withTimeToLive(95344421)
.withAdditionalProperties(mapOf()))
.withPipelineExternalComputeScaleProperties(
- new PipelineExternalComputeScaleProperties().withTimeToLive(670066514)
- .withNumberOfPipelineNodes(2055140017)
- .withNumberOfExternalNodes(1136227748)
+ new PipelineExternalComputeScaleProperties().withTimeToLive(862321993)
+ .withNumberOfPipelineNodes(922478953)
+ .withNumberOfExternalNodes(1537232280)
.withAdditionalProperties(mapOf()))
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(IntegrationRuntimeComputeProperties.class);
- Assertions.assertEquals("zxxzndwtomin", model.location());
- Assertions.assertEquals("f", model.nodeSize());
- Assertions.assertEquals(1479856776, model.numberOfNodes());
- Assertions.assertEquals(2091496981, model.maxParallelExecutionsPerNode());
+ Assertions.assertEquals("c", model.location());
+ Assertions.assertEquals("xevlt", model.nodeSize());
+ Assertions.assertEquals(1736990485, model.numberOfNodes());
+ Assertions.assertEquals(1753770104, model.maxParallelExecutionsPerNode());
Assertions.assertEquals(DataFlowComputeType.GENERAL, model.dataFlowProperties().computeType());
- Assertions.assertEquals(610534246, model.dataFlowProperties().coreCount());
- Assertions.assertEquals(513393962, model.dataFlowProperties().timeToLive());
- Assertions.assertEquals(false, model.dataFlowProperties().cleanup());
- Assertions.assertEquals("q", model.dataFlowProperties().customProperties().get(0).name());
- Assertions.assertEquals("t", model.dataFlowProperties().customProperties().get(0).value());
- Assertions.assertEquals("ysjdfxvksijr", model.vNetProperties().vNetId());
- Assertions.assertEquals("yindex", model.vNetProperties().subnet());
- Assertions.assertEquals("vuyxuu", model.vNetProperties().publicIPs().get(0));
- Assertions.assertEquals("atopdtphvj", model.vNetProperties().subnetId());
- Assertions.assertEquals(1097849397, model.copyComputeScaleProperties().dataIntegrationUnit());
- Assertions.assertEquals(2091236479, model.copyComputeScaleProperties().timeToLive());
- Assertions.assertEquals(670066514, model.pipelineExternalComputeScaleProperties().timeToLive());
- Assertions.assertEquals(2055140017, model.pipelineExternalComputeScaleProperties().numberOfPipelineNodes());
- Assertions.assertEquals(1136227748, model.pipelineExternalComputeScaleProperties().numberOfExternalNodes());
+ Assertions.assertEquals(2045958196, model.dataFlowProperties().coreCount());
+ Assertions.assertEquals(492843137, model.dataFlowProperties().timeToLive());
+ Assertions.assertEquals(true, model.dataFlowProperties().cleanup());
+ Assertions.assertEquals("fmftwr", model.dataFlowProperties().customProperties().get(0).name());
+ Assertions.assertEquals("mriipzgfofuad", model.dataFlowProperties().customProperties().get(0).value());
+ Assertions.assertEquals("ypfreuwvzhn", model.vNetProperties().vNetId());
+ Assertions.assertEquals("vtoiqofzttqg", model.vNetProperties().subnet());
+ Assertions.assertEquals("w", model.vNetProperties().publicIPs().get(0));
+ Assertions.assertEquals("zvtvxxfs", model.vNetProperties().subnetId());
+ Assertions.assertEquals(785813210, model.copyComputeScaleProperties().dataIntegrationUnit());
+ Assertions.assertEquals(95344421, model.copyComputeScaleProperties().timeToLive());
+ Assertions.assertEquals(862321993, model.pipelineExternalComputeScaleProperties().timeToLive());
+ Assertions.assertEquals(922478953, model.pipelineExternalComputeScaleProperties().numberOfPipelineNodes());
+ Assertions.assertEquals(1537232280, model.pipelineExternalComputeScaleProperties().numberOfExternalNodes());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeCustomerVirtualNetworkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeCustomerVirtualNetworkTests.java
index 57621e47b208..46145353993a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeCustomerVirtualNetworkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeCustomerVirtualNetworkTests.java
@@ -11,16 +11,16 @@
public final class IntegrationRuntimeCustomerVirtualNetworkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- IntegrationRuntimeCustomerVirtualNetwork model = BinaryData.fromString("{\"subnetId\":\"lrkvitzkifq\"}")
+ IntegrationRuntimeCustomerVirtualNetwork model = BinaryData.fromString("{\"subnetId\":\"sfvijnubxfiiy\"}")
.toObject(IntegrationRuntimeCustomerVirtualNetwork.class);
- Assertions.assertEquals("lrkvitzkifq", model.subnetId());
+ Assertions.assertEquals("sfvijnubxfiiy", model.subnetId());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
IntegrationRuntimeCustomerVirtualNetwork model
- = new IntegrationRuntimeCustomerVirtualNetwork().withSubnetId("lrkvitzkifq");
+ = new IntegrationRuntimeCustomerVirtualNetwork().withSubnetId("sfvijnubxfiiy");
model = BinaryData.fromObject(model).toObject(IntegrationRuntimeCustomerVirtualNetwork.class);
- Assertions.assertEquals("lrkvitzkifq", model.subnetId());
+ Assertions.assertEquals("sfvijnubxfiiy", model.subnetId());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesCustomPropertiesItemTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesCustomPropertiesItemTests.java
index 55e05c276757..a4e9e11a5453 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesCustomPropertiesItemTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesCustomPropertiesItemTests.java
@@ -12,19 +12,18 @@ public final class IntegrationRuntimeDataFlowPropertiesCustomPropertiesItemTests
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem model
- = BinaryData.fromString("{\"name\":\"fyxhsppv\",\"value\":\"duouoqtenqsomuo\"}")
+ = BinaryData.fromString("{\"name\":\"kubzq\",\"value\":\"dlrkvitzk\"}")
.toObject(IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem.class);
- Assertions.assertEquals("fyxhsppv", model.name());
- Assertions.assertEquals("duouoqtenqsomuo", model.value());
+ Assertions.assertEquals("kubzq", model.name());
+ Assertions.assertEquals("dlrkvitzk", model.value());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem model
- = new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("fyxhsppv")
- .withValue("duouoqtenqsomuo");
+ = new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("kubzq").withValue("dlrkvitzk");
model = BinaryData.fromObject(model).toObject(IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem.class);
- Assertions.assertEquals("fyxhsppv", model.name());
- Assertions.assertEquals("duouoqtenqsomuo", model.value());
+ Assertions.assertEquals("kubzq", model.name());
+ Assertions.assertEquals("dlrkvitzk", model.value());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesTests.java
index 9a79d4e69340..327a1ae22558 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataFlowPropertiesTests.java
@@ -17,40 +17,36 @@ public final class IntegrationRuntimeDataFlowPropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
IntegrationRuntimeDataFlowProperties model = BinaryData.fromString(
- "{\"computeType\":\"MemoryOptimized\",\"coreCount\":1868758992,\"timeToLive\":1928305595,\"cleanup\":false,\"customProperties\":[{\"name\":\"lyduyufdmz\",\"value\":\"xvzvwlxd\"},{\"name\":\"stzeurdoxklrzats\",\"value\":\"nymwzldpkihqhnfu\"},{\"name\":\"vwadxcezxe\",\"value\":\"tfebqoqi\"},{\"name\":\"lqakpstifmftwrph\",\"value\":\"iipz\"}],\"\":{\"neaqk\":\"datafuadcj\",\"gaxoyvgj\":\"datattbargeeynqlsn\"}}")
+ "{\"computeType\":\"ComputeOptimized\",\"coreCount\":2008818770,\"timeToLive\":759424327,\"cleanup\":false,\"customProperties\":[{\"name\":\"tkvomdqxnoyzqipa\",\"value\":\"fccydbjgh\"},{\"name\":\"qnttrw\",\"value\":\"bzvvxdvp\"}],\"\":{\"ai\":\"datawwvx\",\"ogsfovkmam\":\"databic\",\"gunrukcyyaa\":\"datay\"}}")
.toObject(IntegrationRuntimeDataFlowProperties.class);
- Assertions.assertEquals(DataFlowComputeType.MEMORY_OPTIMIZED, model.computeType());
- Assertions.assertEquals(1868758992, model.coreCount());
- Assertions.assertEquals(1928305595, model.timeToLive());
+ Assertions.assertEquals(DataFlowComputeType.COMPUTE_OPTIMIZED, model.computeType());
+ Assertions.assertEquals(2008818770, model.coreCount());
+ Assertions.assertEquals(759424327, model.timeToLive());
Assertions.assertEquals(false, model.cleanup());
- Assertions.assertEquals("lyduyufdmz", model.customProperties().get(0).name());
- Assertions.assertEquals("xvzvwlxd", model.customProperties().get(0).value());
+ Assertions.assertEquals("tkvomdqxnoyzqipa", model.customProperties().get(0).name());
+ Assertions.assertEquals("fccydbjgh", model.customProperties().get(0).value());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
IntegrationRuntimeDataFlowProperties model
- = new IntegrationRuntimeDataFlowProperties().withComputeType(DataFlowComputeType.MEMORY_OPTIMIZED)
- .withCoreCount(1868758992)
- .withTimeToLive(1928305595)
+ = new IntegrationRuntimeDataFlowProperties().withComputeType(DataFlowComputeType.COMPUTE_OPTIMIZED)
+ .withCoreCount(2008818770)
+ .withTimeToLive(759424327)
.withCleanup(false)
.withCustomProperties(Arrays.asList(
- new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("lyduyufdmz")
- .withValue("xvzvwlxd"),
- new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("stzeurdoxklrzats")
- .withValue("nymwzldpkihqhnfu"),
- new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("vwadxcezxe")
- .withValue("tfebqoqi"),
- new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("lqakpstifmftwrph")
- .withValue("iipz")))
+ new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("tkvomdqxnoyzqipa")
+ .withValue("fccydbjgh"),
+ new IntegrationRuntimeDataFlowPropertiesCustomPropertiesItem().withName("qnttrw")
+ .withValue("bzvvxdvp")))
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(IntegrationRuntimeDataFlowProperties.class);
- Assertions.assertEquals(DataFlowComputeType.MEMORY_OPTIMIZED, model.computeType());
- Assertions.assertEquals(1868758992, model.coreCount());
- Assertions.assertEquals(1928305595, model.timeToLive());
+ Assertions.assertEquals(DataFlowComputeType.COMPUTE_OPTIMIZED, model.computeType());
+ Assertions.assertEquals(2008818770, model.coreCount());
+ Assertions.assertEquals(759424327, model.timeToLive());
Assertions.assertEquals(false, model.cleanup());
- Assertions.assertEquals("lyduyufdmz", model.customProperties().get(0).name());
- Assertions.assertEquals("xvzvwlxd", model.customProperties().get(0).value());
+ Assertions.assertEquals("tkvomdqxnoyzqipa", model.customProperties().get(0).name());
+ Assertions.assertEquals("fccydbjgh", model.customProperties().get(0).value());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataProxyPropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataProxyPropertiesTests.java
index d55b60b9a7a2..8c64abbebd46 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataProxyPropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeDataProxyPropertiesTests.java
@@ -14,34 +14,34 @@ public final class IntegrationRuntimeDataProxyPropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
IntegrationRuntimeDataProxyProperties model = BinaryData.fromString(
- "{\"connectVia\":{\"type\":\"IntegrationRuntimeReference\",\"referenceName\":\"v\"},\"stagingLinkedService\":{\"type\":\"LinkedServiceReference\",\"referenceName\":\"wvxcai\"},\"path\":\"icbogsfo\"}")
+ "{\"connectVia\":{\"type\":\"LinkedServiceReference\",\"referenceName\":\"obqysb\"},\"stagingLinkedService\":{\"type\":\"LinkedServiceReference\",\"referenceName\":\"bvvaerszsufzsa\"},\"path\":\"bric\"}")
.toObject(IntegrationRuntimeDataProxyProperties.class);
- Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE,
+ Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE,
model.connectVia().type());
- Assertions.assertEquals("v", model.connectVia().referenceName());
+ Assertions.assertEquals("obqysb", model.connectVia().referenceName());
Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE,
model.stagingLinkedService().type());
- Assertions.assertEquals("wvxcai", model.stagingLinkedService().referenceName());
- Assertions.assertEquals("icbogsfo", model.path());
+ Assertions.assertEquals("bvvaerszsufzsa", model.stagingLinkedService().referenceName());
+ Assertions.assertEquals("bric", model.path());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
IntegrationRuntimeDataProxyProperties model = new IntegrationRuntimeDataProxyProperties()
.withConnectVia(
- new EntityReference().withType(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE)
- .withReferenceName("v"))
+ new EntityReference().withType(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE)
+ .withReferenceName("obqysb"))
.withStagingLinkedService(
new EntityReference().withType(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE)
- .withReferenceName("wvxcai"))
- .withPath("icbogsfo");
+ .withReferenceName("bvvaerszsufzsa"))
+ .withPath("bric");
model = BinaryData.fromObject(model).toObject(IntegrationRuntimeDataProxyProperties.class);
- Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE,
+ Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE,
model.connectVia().type());
- Assertions.assertEquals("v", model.connectVia().referenceName());
+ Assertions.assertEquals("obqysb", model.connectVia().referenceName());
Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE,
model.stagingLinkedService().type());
- Assertions.assertEquals("wvxcai", model.stagingLinkedService().referenceName());
- Assertions.assertEquals("icbogsfo", model.path());
+ Assertions.assertEquals("bvvaerszsufzsa", model.stagingLinkedService().referenceName());
+ Assertions.assertEquals("bric", model.path());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesDeleteWithResponseMockTests.java
index fa11fefd5ea2..669465be6e8d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesDeleteWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.integrationRuntimeNodes()
- .deleteWithResponse("nchtklzvpgttv", "kzdlktenbvpad", "seqc", "ikhbkcvpubvmsz",
+ .deleteWithResponse("njox", "llcsdgmcjsktej", "mhttiqbnfyixkeav", "ezzpfldd",
com.azure.core.util.Context.NONE);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetIpAddressWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetIpAddressWithResponseMockTests.java
index 07724ebce8dc..0ff58cc452a4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetIpAddressWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetIpAddressWithResponseMockTests.java
@@ -19,7 +19,7 @@
public final class IntegrationRuntimeNodesGetIpAddressWithResponseMockTests {
@Test
public void testGetIpAddressWithResponse() throws Exception {
- String responseStr = "{\"ipAddress\":\"iqwftrjdyi\"}";
+ String responseStr = "{\"ipAddress\":\"iwgrj\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -29,7 +29,8 @@ public void testGetIpAddressWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeNodeIpAddress response = manager.integrationRuntimeNodes()
- .getIpAddressWithResponse("opygrsvyjrqhp", "lvmxibp", "n", "psyzkaentip", com.azure.core.util.Context.NONE)
+ .getIpAddressWithResponse("yvzhxzjcbzij", "ykfxg", "mdqghtb", "eltnevbkkdbhgurn",
+ com.azure.core.util.Context.NONE)
.getValue();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetWithResponseMockTests.java
index c59d01f945af..8b1e1c74bd46 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesGetWithResponseMockTests.java
@@ -20,7 +20,7 @@ public final class IntegrationRuntimeNodesGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"nodeName\":\"fxjpgjaynofwyzpn\",\"machineName\":\"pgwriyxyelzm\",\"hostServiceUri\":\"harucpkpm\",\"status\":\"Limited\",\"capabilities\":{\"gxhjbapflluyhivl\":\"obkfutohkrq\",\"rkgtlrmmmsaujx\":\"wipobtbtlmp\",\"hxmwf\":\"ogtwxgswu\",\"txju\":\"ehryordinfwnlif\"},\"versionStatus\":\"ddtubzekfb\",\"version\":\"tyxmel\",\"registerTime\":\"2021-09-13T01:16:21Z\",\"lastConnectTime\":\"2021-09-11T15:49:12Z\",\"expiryTime\":\"2021-04-16T17:13:53Z\",\"lastStartTime\":\"2021-01-01T01:52:32Z\",\"lastStopTime\":\"2021-09-19T14:31:43Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-09-29T21:30:47Z\",\"lastEndUpdateTime\":\"2021-02-26T07:53:48Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":1124062533,\"maxConcurrentJobs\":916889299,\"\":{\"jslk\":\"dataeqruoan\",\"qsxecejlyhuyhqqq\":\"dataawocsetkrtexji\",\"dmyemvyijvvb\":\"datacdzmh\"}}";
+ = "{\"nodeName\":\"jqjoamzdsajn\",\"machineName\":\"kq\",\"hostServiceUri\":\"tdeouqixgt\",\"status\":\"Initializing\",\"capabilities\":{\"aulbfrch\":\"evjjjuwdv\",\"bfekxbcbumjy\":\"ucobpkphxh\"},\"versionStatus\":\"ke\",\"version\":\"ohthsmdu\",\"registerTime\":\"2021-03-23T09:13:38Z\",\"lastConnectTime\":\"2021-06-15T13:12:33Z\",\"expiryTime\":\"2021-05-05T20:12:02Z\",\"lastStartTime\":\"2021-01-23T15:14:58Z\",\"lastStopTime\":\"2021-10-10T05:38:40Z\",\"lastUpdateResult\":\"None\",\"lastStartUpdateTime\":\"2021-02-19T04:20:25Z\",\"lastEndUpdateTime\":\"2021-04-10T00:44:33Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":1388340166,\"maxConcurrentJobs\":77233099,\"\":{\"ehxddmaevcjtrw\":\"datadfreyrgrgft\",\"betsvnloduvcq\":\"datacnwqeixyjlfobj\",\"lfeolhsyskivlz\":\"datawc\",\"iynzdadkurwgty\":\"dataxmqvlgcppn\"}}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -30,7 +30,7 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
SelfHostedIntegrationRuntimeNode response = manager.integrationRuntimeNodes()
- .getWithResponse("brsjgrjtlw", "dcz", "lbzcikhcpd", "hvwyitcgybuuu", com.azure.core.util.Context.NONE)
+ .getWithResponse("kfsgrheakvl", "ukmnu", "vpbjclih", "zriigteqyp", com.azure.core.util.Context.NONE)
.getValue();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesUpdateWithResponseMockTests.java
index faa834647059..645765b33b21 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeNodesUpdateWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class IntegrationRuntimeNodesUpdateWithResponseMockTests {
@Test
public void testUpdateWithResponse() throws Exception {
String responseStr
- = "{\"nodeName\":\"gwbavlgovgthpp\",\"machineName\":\"dn\",\"hostServiceUri\":\"a\",\"status\":\"InitializeFailed\",\"capabilities\":{\"cgap\":\"hvimstbyaklfvcir\",\"imnfvbfj\":\"yof\",\"yjdwdaocwqkxwoq\":\"vspxxbfqlfkwjiui\",\"nhrencxoktsdgnh\":\"ffnojiqtpbfc\"},\"versionStatus\":\"qcc\",\"version\":\"xxytmx\",\"registerTime\":\"2021-08-19T22:14:19Z\",\"lastConnectTime\":\"2021-08-26T08:29:30Z\",\"expiryTime\":\"2021-09-28T16:44:54Z\",\"lastStartTime\":\"2021-08-03T18:43:13Z\",\"lastStopTime\":\"2021-07-04T02:54:39Z\",\"lastUpdateResult\":\"None\",\"lastStartUpdateTime\":\"2021-06-02T05:47:08Z\",\"lastEndUpdateTime\":\"2021-05-15T14:01:31Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":252084786,\"maxConcurrentJobs\":1910937514,\"\":{\"urjynezpewjxc\":\"datartnksl\",\"gi\":\"datavwnptmriqea\",\"vwhjf\":\"dataszgstqsrtz\",\"h\":\"dataoipstvcqhzejbro\"}}";
+ = "{\"nodeName\":\"w\",\"machineName\":\"df\",\"hostServiceUri\":\"q\",\"status\":\"Limited\",\"capabilities\":{\"dsnc\":\"sabyowfrwprbzf\"},\"versionStatus\":\"lgtqrowtaz\",\"version\":\"xwkkjx\",\"registerTime\":\"2021-06-24T12:52:09Z\",\"lastConnectTime\":\"2021-09-26T11:47:54Z\",\"expiryTime\":\"2021-09-06T21:28:54Z\",\"lastStartTime\":\"2021-08-27T15:55:46Z\",\"lastStopTime\":\"2021-10-07T00:16:58Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-08-31T19:56:57Z\",\"lastEndUpdateTime\":\"2021-06-22T04:38:40Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":1091038831,\"maxConcurrentJobs\":1665291142,\"\":{\"fkdf\":\"datairttlwuqgaaj\",\"febtvnskygzqqikt\":\"dataqsbekmeeowdojpja\"}}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,8 +31,8 @@ public void testUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
SelfHostedIntegrationRuntimeNode response = manager.integrationRuntimeNodes()
- .updateWithResponse("zrs", "sxncykfq", "bwes", "gqctrvfpg",
- new UpdateIntegrationRuntimeNodeRequest().withConcurrentJobsLimit(54879885),
+ .updateWithResponse("vcwhodfwv", "xrfr", "x", "yktlofgpnswv",
+ new UpdateIntegrationRuntimeNodeRequest().withConcurrentJobsLimit(1423242353),
com.azure.core.util.Context.NONE)
.getValue();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasGetWithResponseMockTests.java
index 927512ed9833..f1e8df89bee7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasGetWithResponseMockTests.java
@@ -22,7 +22,7 @@ public final class IntegrationRuntimeObjectMetadatasGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"value\":[{\"type\":\"SsisObjectMetadata\",\"id\":3507907459177532864,\"name\":\"nfxwkjhzgmvzfpvi\",\"description\":\"fvzeihlubdjdiq\"},{\"type\":\"SsisObjectMetadata\",\"id\":7604167649090701701,\"name\":\"vrzlupygnlfyddyy\",\"description\":\"dlhytckp\"},{\"type\":\"SsisObjectMetadata\",\"id\":6201066221404190674,\"name\":\"dgnlsnmzlsgal\",\"description\":\"xyovwuhvpipaa\"},{\"type\":\"SsisObjectMetadata\",\"id\":8014468031949571426,\"name\":\"zordp\",\"description\":\"wip\"}],\"nextLink\":\"oxpeyi\"}";
+ = "{\"value\":[{\"type\":\"SsisObjectMetadata\",\"id\":8989974928153576075,\"name\":\"qn\",\"description\":\"mxitvmrq\"},{\"type\":\"SsisObjectMetadata\",\"id\":2339635829156681038,\"name\":\"cmuvskdvqyf\",\"description\":\"wxcabfrvjpfojh\"},{\"type\":\"SsisObjectMetadata\",\"id\":1740640778338465745,\"name\":\"qyohzhund\",\"description\":\"pdxfvjdfusuwght\"},{\"type\":\"SsisObjectMetadata\",\"id\":8786005440905854712,\"name\":\"hfeadedivadpc\",\"description\":\"qpm\"}],\"nextLink\":\"sdzfle\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,13 +32,13 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
SsisObjectMetadataListResponse response = manager.integrationRuntimeObjectMetadatas()
- .getWithResponse("rxsqodesd", "jpeeqy", "ngcv", new GetSsisObjectMetadataRequest().withMetadataPath("v"),
+ .getWithResponse("sd", "swozpm", "hdnx", new GetSsisObjectMetadataRequest().withMetadataPath("fesursb"),
com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals(3507907459177532864L, response.value().get(0).id());
- Assertions.assertEquals("nfxwkjhzgmvzfpvi", response.value().get(0).name());
- Assertions.assertEquals("fvzeihlubdjdiq", response.value().get(0).description());
- Assertions.assertEquals("oxpeyi", response.nextLink());
+ Assertions.assertEquals(8989974928153576075L, response.value().get(0).id());
+ Assertions.assertEquals("qn", response.value().get(0).name());
+ Assertions.assertEquals("mxitvmrq", response.value().get(0).description());
+ Assertions.assertEquals("sdzfle", response.nextLink());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasRefreshMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasRefreshMockTests.java
index 5c2c8f7ecffd..f21a00c8b62a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasRefreshMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeObjectMetadatasRefreshMockTests.java
@@ -21,7 +21,7 @@ public final class IntegrationRuntimeObjectMetadatasRefreshMockTests {
@Test
public void testRefresh() throws Exception {
String responseStr
- = "{\"status\":\"reuhssrdugaxky\",\"name\":\"ljbiupj\",\"properties\":\"ygh\",\"error\":\"cqqvlxnyaeckzc\"}";
+ = "{\"status\":\"mderauohtnjtahd\",\"name\":\"ceuhjxvcj\",\"properties\":\"l\",\"error\":\"yptvrbgcp\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -30,12 +30,12 @@ public void testRefresh() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- SsisObjectMetadataStatusResponse response = manager.integrationRuntimeObjectMetadatas()
- .refresh("wdpnaohher", "yrkbsrpruoyjbzyl", "u", com.azure.core.util.Context.NONE);
+ SsisObjectMetadataStatusResponse response
+ = manager.integrationRuntimeObjectMetadatas().refresh("ce", "qnh", "gbm", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("reuhssrdugaxky", response.status());
- Assertions.assertEquals("ljbiupj", response.name());
- Assertions.assertEquals("ygh", response.properties());
- Assertions.assertEquals("cqqvlxnyaeckzc", response.error());
+ Assertions.assertEquals("mderauohtnjtahd", response.status());
+ Assertions.assertEquals("ceuhjxvcj", response.name());
+ Assertions.assertEquals("l", response.properties());
+ Assertions.assertEquals("yptvrbgcp", response.error());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeVNetPropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeVNetPropertiesTests.java
index 3182abe5ee51..db2e6138930e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeVNetPropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimeVNetPropertiesTests.java
@@ -15,26 +15,26 @@ public final class IntegrationRuntimeVNetPropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
IntegrationRuntimeVNetProperties model = BinaryData.fromString(
- "{\"vNetId\":\"qe\",\"subnet\":\"aseqcppypfre\",\"publicIPs\":[\"zhndyv\"],\"subnetId\":\"iqofzttqgtll\",\"\":{\"itpqvpivrsgqbm\":\"dataxzuhel\",\"tvxx\":\"datalxeomebz\",\"cuedybkbgdwbmi\":\"datasfoyacgihnal\"}}")
+ "{\"vNetId\":\"qbxmnnidotmp\",\"subnet\":\"zuh\",\"publicIPs\":[\"ttqhpvaru\"],\"subnetId\":\"uwj\",\"\":{\"gmrodb\":\"dataqfpqqllavzlh\",\"z\":\"dataapqra\"}}")
.toObject(IntegrationRuntimeVNetProperties.class);
- Assertions.assertEquals("qe", model.vNetId());
- Assertions.assertEquals("aseqcppypfre", model.subnet());
- Assertions.assertEquals("zhndyv", model.publicIPs().get(0));
- Assertions.assertEquals("iqofzttqgtll", model.subnetId());
+ Assertions.assertEquals("qbxmnnidotmp", model.vNetId());
+ Assertions.assertEquals("zuh", model.subnet());
+ Assertions.assertEquals("ttqhpvaru", model.publicIPs().get(0));
+ Assertions.assertEquals("uwj", model.subnetId());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- IntegrationRuntimeVNetProperties model = new IntegrationRuntimeVNetProperties().withVNetId("qe")
- .withSubnet("aseqcppypfre")
- .withPublicIPs(Arrays.asList("zhndyv"))
- .withSubnetId("iqofzttqgtll")
+ IntegrationRuntimeVNetProperties model = new IntegrationRuntimeVNetProperties().withVNetId("qbxmnnidotmp")
+ .withSubnet("zuh")
+ .withPublicIPs(Arrays.asList("ttqhpvaru"))
+ .withSubnetId("uwj")
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(IntegrationRuntimeVNetProperties.class);
- Assertions.assertEquals("qe", model.vNetId());
- Assertions.assertEquals("aseqcppypfre", model.subnet());
- Assertions.assertEquals("zhndyv", model.publicIPs().get(0));
- Assertions.assertEquals("iqofzttqgtll", model.subnetId());
+ Assertions.assertEquals("qbxmnnidotmp", model.vNetId());
+ Assertions.assertEquals("zuh", model.subnet());
+ Assertions.assertEquals("ttqhpvaru", model.publicIPs().get(0));
+ Assertions.assertEquals("uwj", model.subnetId());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateLinkedIntegrationRuntimeWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateLinkedIntegrationRuntimeWithResponseMockTests.java
index b17863806c72..386dc186c86e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateLinkedIntegrationRuntimeWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateLinkedIntegrationRuntimeWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class IntegrationRuntimesCreateLinkedIntegrationRuntimeWithResponse
@Test
public void testCreateLinkedIntegrationRuntimeWithResponse() throws Exception {
String responseStr
- = "{\"name\":\"z\",\"properties\":{\"type\":\"IntegrationRuntimeStatus\",\"dataFactoryName\":\"hmkoxsavzngpaw\",\"state\":\"Started\",\"\":{\"fz\":\"datac\",\"zr\":\"dataqqtpwhicnnan\",\"puzxinw\":\"datalbdptmzsdwxls\",\"zdfpeauhld\":\"datauqzjr\"}}}";
+ = "{\"name\":\"byrvguojky\",\"properties\":{\"type\":\"IntegrationRuntimeStatus\",\"dataFactoryName\":\"lmzrfhlynkiusbyy\",\"state\":\"AccessDenied\",\"\":{\"atuiqc\":\"dataqfhnqxqtemvqxxuw\",\"xjk\":\"dataylkdbyo\"}}}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,11 +31,11 @@ public void testCreateLinkedIntegrationRuntimeWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeStatusResponse response = manager.integrationRuntimes()
- .createLinkedIntegrationRuntimeWithResponse("usln", "qyknsdwc", "yagidyansnun",
- new CreateLinkedIntegrationRuntimeRequest().withName("qtvg")
- .withSubscriptionId("erbnbsdyvrds")
- .withDataFactoryName("jgtqqrmi")
- .withDataFactoryLocation("nmxspzti"),
+ .createLinkedIntegrationRuntimeWithResponse("os", "demfatftzxtrjru", "ljfdc",
+ new CreateLinkedIntegrationRuntimeRequest().withName("p")
+ .withSubscriptionId("zflydywbn")
+ .withDataFactoryName("ygsifsahkc")
+ .withDataFactoryLocation("vajnsu"),
com.azure.core.util.Context.NONE)
.getValue();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateOrUpdateWithResponseMockTests.java
index 5db25a38071d..ad0327a858c3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesCreateOrUpdateWithResponseMockTests.java
@@ -24,7 +24,7 @@ public final class IntegrationRuntimesCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"IntegrationRuntime\",\"description\":\"vqbavp\",\"\":{\"uji\":\"datacsrbvvniwqpcqy\",\"j\":\"datavrkpul\",\"yr\":\"datafy\",\"lzlkugkgnu\":\"datapclvpnoayckzshvc\"}},\"name\":\"aeqposnnwnz\",\"type\":\"kvjevjapsopjhaqu\",\"etag\":\"uypcnno\",\"id\":\"syqailqtqrtkdeyu\"}";
+ = "{\"properties\":{\"type\":\"IntegrationRuntime\",\"description\":\"eb\",\"\":{\"ytkehfoephiphoyg\":\"datadlahrd\",\"q\":\"datac\"}},\"name\":\"uk\",\"type\":\"vhqism\",\"etag\":\"logfxbvl\",\"id\":\"fdnaj\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -34,15 +34,15 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeResource response = manager.integrationRuntimes()
- .define("cyg")
- .withExistingFactory("bwkxevnroew", "rhvdwrow")
- .withProperties(new IntegrationRuntime().withDescription("jhc")
+ .define("jgvuvjsnbhnuujkj")
+ .withExistingFactory("avppos", "imtouclsabjzh")
+ .withProperties(new IntegrationRuntime().withDescription("yewtlomagxaqvra")
.withAdditionalProperties(mapOf("type", "IntegrationRuntime")))
- .withIfMatch("xicjl")
+ .withIfMatch("ifptynhulefltub")
.create();
- Assertions.assertEquals("syqailqtqrtkdeyu", response.id());
- Assertions.assertEquals("vqbavp", response.properties().description());
+ Assertions.assertEquals("fdnaj", response.id());
+ Assertions.assertEquals("eb", response.properties().description());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesDeleteWithResponseMockTests.java
index 93c518f26454..99bfea794a18 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesDeleteWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.integrationRuntimes()
- .deleteWithResponse("mdlhxwwhusrod", "omozafwq", "ocwkwmqroqldacx", com.azure.core.util.Context.NONE);
+ .deleteWithResponse("yfi", "lpiqei", "jboghjdihtc", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetMonitoringDataWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetMonitoringDataWithResponseMockTests.java
index d24a44fde901..1b1a20a1248e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetMonitoringDataWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetMonitoringDataWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class IntegrationRuntimesGetMonitoringDataWithResponseMockTests {
@Test
public void testGetMonitoringDataWithResponse() throws Exception {
String responseStr
- = "{\"name\":\"uwbrwoyqty\",\"nodes\":[{\"nodeName\":\"ccumk\",\"availableMemoryInMB\":728800792,\"cpuUtilization\":436941349,\"concurrentJobsLimit\":1852688001,\"concurrentJobsRunning\":2013623616,\"maxConcurrentJobs\":1911258771,\"sentBytes\":4.5306683,\"receivedBytes\":32.07864,\"\":{\"lrfqst\":\"datarbotzvrgoxpayjs\",\"qmlnefvbeyugggf\":\"dataf\",\"aevrkxyjsuappdm\":\"datahntykenmjznjqrxy\",\"syoybjtzdgzt\":\"datajiguusbw\"}},{\"nodeName\":\"qiilfovmcjchbof\",\"availableMemoryInMB\":626803302,\"cpuUtilization\":1317203532,\"concurrentJobsLimit\":867009902,\"concurrentJobsRunning\":299777437,\"maxConcurrentJobs\":1143361378,\"sentBytes\":26.287401,\"receivedBytes\":81.01534,\"\":{\"rcjgkauyzbrd\":\"dataeznkrer\",\"gxqsbwepduyqxv\":\"databdb\",\"yftwdprtpxwgtt\":\"dataxarddbnqyayl\"}},{\"nodeName\":\"bjihz\",\"availableMemoryInMB\":1190147943,\"cpuUtilization\":765252755,\"concurrentJobsLimit\":832580974,\"concurrentJobsRunning\":1491820891,\"maxConcurrentJobs\":2117066441,\"sentBytes\":27.401001,\"receivedBytes\":71.859505,\"\":{\"lqnoeyfufleioyw\":\"datazwstytexueugq\",\"kt\":\"dataclhbytshsat\",\"yzjq\":\"datawqljnuayp\"}},{\"nodeName\":\"qajipnpwom\",\"availableMemoryInMB\":1489726911,\"cpuUtilization\":1683883253,\"concurrentJobsLimit\":508436125,\"concurrentJobsRunning\":961704290,\"maxConcurrentJobs\":2081574756,\"sentBytes\":69.46848,\"receivedBytes\":39.533035,\"\":{\"nw\":\"datadnp\",\"lwoozlfliiru\":\"dataqag\"}}]}";
+ = "{\"name\":\"pkskbidmzzjp\",\"nodes\":[{\"nodeName\":\"esbteqfenhli\",\"availableMemoryInMB\":346827501,\"cpuUtilization\":981268010,\"concurrentJobsLimit\":855967901,\"concurrentJobsRunning\":1611200927,\"maxConcurrentJobs\":2069802386,\"sentBytes\":88.11751,\"receivedBytes\":6.6926837,\"\":{\"rjkinofwzci\":\"datadhxamjhpqfjpef\",\"qesyifdrbkprblw\":\"datal\",\"qqts\":\"databjse\"}},{\"nodeName\":\"pogtrwkuwna\",\"availableMemoryInMB\":560037150,\"cpuUtilization\":692226376,\"concurrentJobsLimit\":34678653,\"concurrentJobsRunning\":1020953911,\"maxConcurrentJobs\":142241566,\"sentBytes\":79.9216,\"receivedBytes\":71.34564,\"\":{\"tsgovnr\":\"dataovgipq\",\"tcrxcnuyfvri\":\"datayb\",\"onnvay\":\"datazqoi\"}}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,10 +31,10 @@ public void testGetMonitoringDataWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeMonitoringData response = manager.integrationRuntimes()
- .getMonitoringDataWithResponse("imnfvqaqtzo", "ulwdhjb", "hflbchzoboeeiakw",
+ .getMonitoringDataWithResponse("owvjupxibu", "gtrnjzbvbwabily", "mfaxepuvwahfnlks",
com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("uwbrwoyqty", response.name());
+ Assertions.assertEquals("pkskbidmzzjp", response.name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetStatusWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetStatusWithResponseMockTests.java
index 830216d59026..12dfebdc0dec 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetStatusWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetStatusWithResponseMockTests.java
@@ -20,7 +20,7 @@ public final class IntegrationRuntimesGetStatusWithResponseMockTests {
@Test
public void testGetStatusWithResponse() throws Exception {
String responseStr
- = "{\"name\":\"irvxahxys\",\"properties\":{\"type\":\"IntegrationRuntimeStatus\",\"dataFactoryName\":\"xokfomakmiychduf\",\"state\":\"Started\",\"\":{\"gzcbvxyqprchkmf\":\"datau\",\"ndzfyp\":\"dataraoytkkqoaazvmn\",\"qboy\":\"datasrfpihvijsjtkpo\"}}}";
+ = "{\"name\":\"ptvmtnougmf\",\"properties\":{\"type\":\"IntegrationRuntimeStatus\",\"dataFactoryName\":\"s\",\"state\":\"Online\",\"\":{\"szpusbfgjrk\":\"dataih\",\"bfoldbbli\":\"dataeprpn\",\"nzrrkmanrowdqo\":\"datajgyrpvmaywpraovq\"}}}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -30,7 +30,7 @@ public void testGetStatusWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeStatusResponse response = manager.integrationRuntimes()
- .getStatusWithResponse("faqassukvsgk", "xznctxocznsz", "jzsjfcaqpkpv", com.azure.core.util.Context.NONE)
+ .getStatusWithResponse("ddfvdktbaexbvyu", "rbycuuxgda", "flil", com.azure.core.util.Context.NONE)
.getValue();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetWithResponseMockTests.java
index 061d0d432121..9f1f298b44b5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class IntegrationRuntimesGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"IntegrationRuntime\",\"description\":\"dpwpz\",\"\":{\"kgjdn\":\"dataynxlkloqpwsaqcre\"}},\"name\":\"wpvrwec\",\"type\":\"kiaognmanrzjprlq\",\"etag\":\"wpejtszjbvjcvw\",\"id\":\"cvnowzcli\"}";
+ = "{\"properties\":{\"type\":\"IntegrationRuntime\",\"description\":\"zq\",\"\":{\"f\":\"datao\",\"qjvju\":\"datalibwdkjq\",\"tz\":\"datajqjxobmvf\"}},\"name\":\"rtarneug\",\"type\":\"pkjyo\",\"etag\":\"wcxedkkd\",\"id\":\"frisreh\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,10 +31,10 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeResource response = manager.integrationRuntimes()
- .getWithResponse("taeallsxfzantssb", "moq", "j", "nhmxkgxrf", com.azure.core.util.Context.NONE)
+ .getWithResponse("eel", "mavinumdngqyvzzr", "ikanybo", "agaigtpj", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("cvnowzcli", response.id());
- Assertions.assertEquals("dpwpz", response.properties().description());
+ Assertions.assertEquals("frisreh", response.id());
+ Assertions.assertEquals("zq", response.properties().description());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListByFactoryMockTests.java
index 72bb3854fd89..f7361a4e80cf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class IntegrationRuntimesListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"type\":\"IntegrationRuntime\",\"description\":\"sumzfvrakpqlltoi\",\"\":{\"bsbhaqsu\":\"dataeoibehrholjjxi\",\"euj\":\"datawdcgdkwwulj\",\"nhmnswlf\":\"datasxrsxbofmvau\"}},\"name\":\"kildl\",\"type\":\"tviwvej\",\"etag\":\"zk\",\"id\":\"dpssklm\"}]}";
+ = "{\"value\":[{\"properties\":{\"type\":\"IntegrationRuntime\",\"description\":\"iiudnmojjmimy\",\"\":{\"ovzmijirpwlt\":\"dataaotaaxl\"}},\"name\":\"mumba\",\"type\":\"ms\",\"etag\":\"udnkrwwc\",\"id\":\"qeiguxix\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,9 +32,9 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.integrationRuntimes().listByFactory("yabglsarfmjsch", "xudrom", com.azure.core.util.Context.NONE);
+ = manager.integrationRuntimes().listByFactory("i", "xz", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("dpssklm", response.iterator().next().id());
- Assertions.assertEquals("sumzfvrakpqlltoi", response.iterator().next().properties().description());
+ Assertions.assertEquals("qeiguxix", response.iterator().next().id());
+ Assertions.assertEquals("iiudnmojjmimy", response.iterator().next().properties().description());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListOutboundNetworkDependenciesEndpointsWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListOutboundNetworkDependenciesEndpointsWithResponseMockTests.java
index e5cfd5723fb8..74572aa4dcd4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListOutboundNetworkDependenciesEndpointsWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesListOutboundNetworkDependenciesEndpointsWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class IntegrationRuntimesListOutboundNetworkDependenciesEndpointsWi
@Test
public void testListOutboundNetworkDependenciesEndpointsWithResponse() throws Exception {
String responseStr
- = "{\"value\":[{\"category\":\"qpjstc\",\"endpoints\":[{\"domainName\":\"odfybafenwvv\",\"endpointDetails\":[{}]}]}]}";
+ = "{\"value\":[{\"category\":\"fdyessiie\",\"endpoints\":[{\"domainName\":\"exi\",\"endpointDetails\":[{},{}]}]}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,11 +31,11 @@ public void testListOutboundNetworkDependenciesEndpointsWithResponse() throws Ex
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeOutboundNetworkDependenciesEndpointsResponse response = manager.integrationRuntimes()
- .listOutboundNetworkDependenciesEndpointsWithResponse("jfxznjduy", "tqbfqtxbtuxm", "grixolbzjl",
+ .listOutboundNetworkDependenciesEndpointsWithResponse("xyabvvbsil", "hs", "es",
com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("qpjstc", response.value().get(0).category());
- Assertions.assertEquals("odfybafenwvv", response.value().get(0).endpoints().get(0).domainName());
+ Assertions.assertEquals("fdyessiie", response.value().get(0).category());
+ Assertions.assertEquals("exi", response.value().get(0).endpoints().get(0).domainName());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesRemoveLinksWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesRemoveLinksWithResponseMockTests.java
index 6335fba1660f..1b40ab15d6e3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesRemoveLinksWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesRemoveLinksWithResponseMockTests.java
@@ -29,8 +29,8 @@ public void testRemoveLinksWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.integrationRuntimes()
- .removeLinksWithResponse("jssfwojfng", "hzrjsbwdsit", "pashvjrin",
- new LinkedIntegrationRuntimeRequest().withLinkedFactoryName("ztga"), com.azure.core.util.Context.NONE);
+ .removeLinksWithResponse("dqop", "abrzrhdezlhsdcp", "bolczhyqdvxqo",
+ new LinkedIntegrationRuntimeRequest().withLinkedFactoryName("j"), com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStartMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStartMockTests.java
index 0d9fe4b729d2..fdbd9e81dc71 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStartMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStartMockTests.java
@@ -20,7 +20,7 @@ public final class IntegrationRuntimesStartMockTests {
@Test
public void testStart() throws Exception {
String responseStr
- = "{\"name\":\"dirxprxlgzpnrm\",\"properties\":{\"type\":\"IntegrationRuntimeStatus\",\"dataFactoryName\":\"yvmxtju\",\"state\":\"Stopping\",\"\":{\"lteiu\":\"dataky\",\"hvfcw\":\"datavrpvhivvlmzcvpo\",\"oezgibfisfmc\":\"datadyze\"}}}";
+ = "{\"name\":\"ighnunptjmz\",\"properties\":{\"type\":\"IntegrationRuntimeStatus\",\"dataFactoryName\":\"rjnddaov\",\"state\":\"Started\",\"\":{\"cvjdvxucqxjxxmsi\":\"dataztrln\",\"yclv\":\"dataliegzjktfsci\",\"woahfaqlcq\":\"dataivsagrfjhcrq\"}}}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -30,7 +30,7 @@ public void testStart() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
IntegrationRuntimeStatusResponse response = manager.integrationRuntimes()
- .start("lsrxzatlzwrpjoqc", "owzwshsgre", "cp", com.azure.core.util.Context.NONE);
+ .start("j", "wgakghvaqbk", "zmwbxautspnyutf", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStopMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStopMockTests.java
index 557b7dbda41d..1d63a02d857d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStopMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesStopMockTests.java
@@ -27,7 +27,8 @@ public void testStop() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.integrationRuntimes().stop("arhgcuejtxxlko", "tbclpvw", "w", com.azure.core.util.Context.NONE);
+ manager.integrationRuntimes()
+ .stop("nwvqifptvfsvrjd", "zvhxssnqqivv", "vuyxsnm", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesSyncCredentialsWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesSyncCredentialsWithResponseMockTests.java
index e698403ff70e..cbff369715f5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesSyncCredentialsWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesSyncCredentialsWithResponseMockTests.java
@@ -28,7 +28,8 @@ public void testSyncCredentialsWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.integrationRuntimes()
- .syncCredentialsWithResponse("oxgrvsavoq", "squwkuszl", "ognledhvlleny", com.azure.core.util.Context.NONE);
+ .syncCredentialsWithResponse("innisuuakaadbwhs", "xmvkcu", "wseoqkaleknea",
+ com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesUpgradeWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesUpgradeWithResponseMockTests.java
index 9eb53e12f4c0..e589d84f7567 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesUpgradeWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/IntegrationRuntimesUpgradeWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testUpgradeWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.integrationRuntimes()
- .upgradeWithResponse("nglfcrtkpfsjwtq", "o", "eofjoqjmlzlki", com.azure.core.util.Context.NONE);
+ .upgradeWithResponse("o", "bigzlvqmy", "pojbifixdgkvlze", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraObjectDatasetTests.java
index a9f04ab462d2..15f1bd79c7ac 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraObjectDatasetTests.java
@@ -19,31 +19,31 @@ public final class JiraObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
JiraObjectDataset model = BinaryData.fromString(
- "{\"type\":\"JiraObject\",\"typeProperties\":{\"tableName\":\"datazc\"},\"description\":\"kckrnovqdmh\",\"structure\":\"datajstfs\",\"schema\":\"datacjakgkqwx\",\"linkedServiceName\":{\"referenceName\":\"dsoqzhxwdjoxwkb\",\"parameters\":{\"lfhn\":\"dataobvcnsbioez\",\"t\":\"dataz\"}},\"parameters\":{\"cmwbejywwwvn\":{\"type\":\"Bool\",\"defaultValue\":\"datagtkxncwdytnlr\"}},\"annotations\":[\"datakrmqevrhhafqf\",\"datadfyziruqvgnjxi\",\"datakgyjmzbm\"],\"folder\":{\"name\":\"kyluyug\"},\"\":{\"loxtvq\":\"datadcv\",\"ryhmmglv\":\"datab\",\"nkpsvokkyankxvc\":\"datab\"}}")
+ "{\"type\":\"JiraObject\",\"typeProperties\":{\"tableName\":\"datawenbqvpr\"},\"description\":\"voqatdjkaldpmec\",\"structure\":\"dataxfzynfemq\",\"schema\":\"datakkp\",\"linkedServiceName\":{\"referenceName\":\"wgssdquupirnb\",\"parameters\":{\"pvirzyud\":\"datayvdsqxkjwd\"}},\"parameters\":{\"xmlfouqpskva\":{\"type\":\"Object\",\"defaultValue\":\"datax\"}},\"annotations\":[\"datapmrrhyjx\"],\"folder\":{\"name\":\"acz\"},\"\":{\"jqyfy\":\"dataaeztt\",\"f\":\"dataqlyyslg\"}}")
.toObject(JiraObjectDataset.class);
- Assertions.assertEquals("kckrnovqdmh", model.description());
- Assertions.assertEquals("dsoqzhxwdjoxwkb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("cmwbejywwwvn").type());
- Assertions.assertEquals("kyluyug", model.folder().name());
+ Assertions.assertEquals("voqatdjkaldpmec", model.description());
+ Assertions.assertEquals("wgssdquupirnb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xmlfouqpskva").type());
+ Assertions.assertEquals("acz", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- JiraObjectDataset model = new JiraObjectDataset().withDescription("kckrnovqdmh")
- .withStructure("datajstfs")
- .withSchema("datacjakgkqwx")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dsoqzhxwdjoxwkb")
- .withParameters(mapOf("lfhn", "dataobvcnsbioez", "t", "dataz")))
- .withParameters(mapOf("cmwbejywwwvn",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datagtkxncwdytnlr")))
- .withAnnotations(Arrays.asList("datakrmqevrhhafqf", "datadfyziruqvgnjxi", "datakgyjmzbm"))
- .withFolder(new DatasetFolder().withName("kyluyug"))
- .withTableName("datazc");
+ JiraObjectDataset model = new JiraObjectDataset().withDescription("voqatdjkaldpmec")
+ .withStructure("dataxfzynfemq")
+ .withSchema("datakkp")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("wgssdquupirnb")
+ .withParameters(mapOf("pvirzyud", "datayvdsqxkjwd")))
+ .withParameters(mapOf("xmlfouqpskva",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datax")))
+ .withAnnotations(Arrays.asList("datapmrrhyjx"))
+ .withFolder(new DatasetFolder().withName("acz"))
+ .withTableName("datawenbqvpr");
model = BinaryData.fromObject(model).toObject(JiraObjectDataset.class);
- Assertions.assertEquals("kckrnovqdmh", model.description());
- Assertions.assertEquals("dsoqzhxwdjoxwkb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("cmwbejywwwvn").type());
- Assertions.assertEquals("kyluyug", model.folder().name());
+ Assertions.assertEquals("voqatdjkaldpmec", model.description());
+ Assertions.assertEquals("wgssdquupirnb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xmlfouqpskva").type());
+ Assertions.assertEquals("acz", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraSourceTests.java
index 73f8c9502959..aecf98023c65 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JiraSourceTests.java
@@ -11,19 +11,19 @@ public final class JiraSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
JiraSource model = BinaryData.fromString(
- "{\"type\":\"JiraSource\",\"query\":\"databrcdumkqhatckom\",\"queryTimeout\":\"datafjs\",\"additionalColumns\":\"datavzvkddaeiepvjr\",\"sourceRetryCount\":\"dataksx\",\"sourceRetryWait\":\"datakb\",\"maxConcurrentConnections\":\"datauawokrhhj\",\"disableMetricsCollection\":\"datahrmuwvs\",\"\":{\"imgg\":\"datauosidtxmbnm\"}}")
+ "{\"type\":\"JiraSource\",\"query\":\"dataylvrofhhitjhh\",\"queryTimeout\":\"datavwrc\",\"additionalColumns\":\"datahllmblls\",\"sourceRetryCount\":\"datafdrimoopfr\",\"sourceRetryWait\":\"datajjrhxornuoqpob\",\"maxConcurrentConnections\":\"datarsdx\",\"disableMetricsCollection\":\"datamq\",\"\":{\"lseoixqp\":\"databqyavcxj\",\"fsuwcmzpwkca\":\"datamsfqntakroxku\",\"zq\":\"datafq\"}}")
.toObject(JiraSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- JiraSource model = new JiraSource().withSourceRetryCount("dataksx")
- .withSourceRetryWait("datakb")
- .withMaxConcurrentConnections("datauawokrhhj")
- .withDisableMetricsCollection("datahrmuwvs")
- .withQueryTimeout("datafjs")
- .withAdditionalColumns("datavzvkddaeiepvjr")
- .withQuery("databrcdumkqhatckom");
+ JiraSource model = new JiraSource().withSourceRetryCount("datafdrimoopfr")
+ .withSourceRetryWait("datajjrhxornuoqpob")
+ .withMaxConcurrentConnections("datarsdx")
+ .withDisableMetricsCollection("datamq")
+ .withQueryTimeout("datavwrc")
+ .withAdditionalColumns("datahllmblls")
+ .withQuery("dataylvrofhhitjhh");
model = BinaryData.fromObject(model).toObject(JiraSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonReadSettingsTests.java
index ff9472bbdac3..8a98018f9ba3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonReadSettingsTests.java
@@ -14,7 +14,7 @@ public final class JsonReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
JsonReadSettings model = BinaryData.fromString(
- "{\"type\":\"JsonReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"gbkzqbomfh\":\"dataoukvin\",\"lmyfhclxwedetawl\":\"datayas\",\"t\":\"dataatvfddqspd\",\"vcvekqjdruml\":\"dataqjtszqexcqcwbx\"}},\"\":{\"lfvmwuyar\":\"datawwqh\",\"dfbdanf\":\"datawsvtzotmwx\",\"qj\":\"dataxlawk\",\"wrtmjskb\":\"dataz\"}}")
+ "{\"type\":\"JsonReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"gcjssqpk\":\"datadiuyqdjk\"}},\"\":{\"h\":\"datayhv\",\"iwuver\":\"datavupbzqwwttqj\",\"co\":\"dataavbjv\",\"djoorbuuhbcck\":\"dataupshoofaskyy\"}}")
.toObject(JsonReadSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSinkTests.java
index cb6e9b5e555e..d249beeba9c1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSinkTests.java
@@ -17,25 +17,25 @@ public final class JsonSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
JsonSink model = BinaryData.fromString(
- "{\"type\":\"JsonSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datatsduf\",\"disableMetricsCollection\":\"databvvkuzyg\",\"copyBehavior\":\"datazubdtzsachmh\",\"metadata\":[{\"name\":\"datanpkkbxkzc\",\"value\":\"dataosralbxhdxnlu\"},{\"name\":\"datawuafbh\",\"value\":\"dataaqf\"}],\"\":{\"rmlbkvqogzaw\":\"datap\"}},\"formatSettings\":{\"type\":\"JsonWriteSettings\",\"filePattern\":\"datadnxum\",\"\":{\"qwsyntcwrluqa\":\"datanvscyu\"}},\"writeBatchSize\":\"datalygfvbfejb\",\"writeBatchTimeout\":\"dataklgpifvpsmvksa\",\"sinkRetryCount\":\"datamsnplqfivxfqmdjz\",\"sinkRetryWait\":\"datavmkplrjkmpaxoey\",\"maxConcurrentConnections\":\"dataofaogvmqzagrqcqh\",\"disableMetricsCollection\":\"dataskmkdr\",\"\":{\"ldwcxjvexlutxcmc\":\"datapn\",\"yypvhdulds\":\"datacotqocn\"}}")
+ "{\"type\":\"JsonSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"dataspfwmfc\",\"disableMetricsCollection\":\"datatoxsthjyyiry\",\"copyBehavior\":\"dataqmkmwdoknvyilh\",\"metadata\":[{\"name\":\"datadioxgs\",\"value\":\"dataxoyrgvrt\"},{\"name\":\"datatmzglbplqhbrar\",\"value\":\"datadepsxufyqcqf\"}],\"\":{\"xgxbgochpxps\":\"dataye\"}},\"formatSettings\":{\"type\":\"JsonWriteSettings\",\"filePattern\":\"datawsioozrugb\",\"\":{\"zjjtapvqjebtd\":\"datalwckuvlz\"}},\"writeBatchSize\":\"datagkeexsozpkvylvty\",\"writeBatchTimeout\":\"datatfqpmpywwybu\",\"sinkRetryCount\":\"datamjc\",\"sinkRetryWait\":\"dataoecdqun\",\"maxConcurrentConnections\":\"dataqcocc\",\"disableMetricsCollection\":\"dataxjrr\",\"\":{\"uoup\":\"databnkqps\"}}")
.toObject(JsonSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- JsonSink model = new JsonSink().withWriteBatchSize("datalygfvbfejb")
- .withWriteBatchTimeout("dataklgpifvpsmvksa")
- .withSinkRetryCount("datamsnplqfivxfqmdjz")
- .withSinkRetryWait("datavmkplrjkmpaxoey")
- .withMaxConcurrentConnections("dataofaogvmqzagrqcqh")
- .withDisableMetricsCollection("dataskmkdr")
- .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datatsduf")
- .withDisableMetricsCollection("databvvkuzyg")
- .withCopyBehavior("datazubdtzsachmh")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datanpkkbxkzc").withValue("dataosralbxhdxnlu"),
- new MetadataItem().withName("datawuafbh").withValue("dataaqf")))
+ JsonSink model = new JsonSink().withWriteBatchSize("datagkeexsozpkvylvty")
+ .withWriteBatchTimeout("datatfqpmpywwybu")
+ .withSinkRetryCount("datamjc")
+ .withSinkRetryWait("dataoecdqun")
+ .withMaxConcurrentConnections("dataqcocc")
+ .withDisableMetricsCollection("dataxjrr")
+ .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("dataspfwmfc")
+ .withDisableMetricsCollection("datatoxsthjyyiry")
+ .withCopyBehavior("dataqmkmwdoknvyilh")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datadioxgs").withValue("dataxoyrgvrt"),
+ new MetadataItem().withName("datatmzglbplqhbrar").withValue("datadepsxufyqcqf")))
.withAdditionalProperties(mapOf("type", "StoreWriteSettings")))
- .withFormatSettings(new JsonWriteSettings().withFilePattern("datadnxum"));
+ .withFormatSettings(new JsonWriteSettings().withFilePattern("datawsioozrugb"));
model = BinaryData.fromObject(model).toObject(JsonSink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSourceTests.java
index 8c01dd4d2db4..87832f6bc533 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonSourceTests.java
@@ -16,22 +16,22 @@ public final class JsonSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
JsonSource model = BinaryData.fromString(
- "{\"type\":\"JsonSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datafk\",\"disableMetricsCollection\":\"datal\",\"\":{\"aihlvrsqci\":\"datamd\"}},\"formatSettings\":{\"type\":\"JsonReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"azgtbynxsh\":\"databwgaccvwkyne\",\"zvuzxx\":\"dataawexgeqo\",\"hbobuovsvwnpcx\":\"dataojj\"}},\"\":{\"bnyhmlpzd\":\"datatvpary\",\"zbpocu\":\"datavotuc\",\"z\":\"dataqzf\"}},\"additionalColumns\":\"datamzdnvno\",\"sourceRetryCount\":\"datalgrenuqsgertx\",\"sourceRetryWait\":\"dataemgsncbb\",\"maxConcurrentConnections\":\"datakphaed\",\"disableMetricsCollection\":\"datalbnu\",\"\":{\"viaaep\":\"dataswmccyk\",\"kz\":\"datalxbofdchboacf\",\"ixtrnakytzcm\":\"dataesetutqjsojw\"}}")
+ "{\"type\":\"JsonSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"dataiksjpkign\",\"disableMetricsCollection\":\"datao\",\"\":{\"ipbfs\":\"datai\",\"kkkgiecjyf\":\"datapslpevzpqydn\",\"f\":\"datasn\",\"tjc\":\"dataz\"}},\"formatSettings\":{\"type\":\"JsonReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"q\":\"datab\",\"xuhhvgddfzcny\":\"dataagpdsuyywnaqgo\"}},\"\":{\"degfhofo\":\"datalhufsgcpwrtg\",\"xvkqjpovjvvxps\":\"datatbiuikpotjjfe\"}},\"additionalColumns\":\"dataewrb\",\"sourceRetryCount\":\"dataj\",\"sourceRetryWait\":\"dataflqwqcxyiqppacji\",\"maxConcurrentConnections\":\"datallacylbtkxeij\",\"disableMetricsCollection\":\"datanlaaxtte\",\"\":{\"wlntenhnqtvx\":\"datagojvgjezrwbob\",\"eojl\":\"datahbehhehotqorrvwl\",\"fdsgrtkevim\":\"dataugzlvgjirjkkrs\",\"klbfvtzdtw\":\"dataupgevjmandrvvj\"}}")
.toObject(JsonSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- JsonSource model = new JsonSource().withSourceRetryCount("datalgrenuqsgertx")
- .withSourceRetryWait("dataemgsncbb")
- .withMaxConcurrentConnections("datakphaed")
- .withDisableMetricsCollection("datalbnu")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datafk")
- .withDisableMetricsCollection("datal")
+ JsonSource model = new JsonSource().withSourceRetryCount("dataj")
+ .withSourceRetryWait("dataflqwqcxyiqppacji")
+ .withMaxConcurrentConnections("datallacylbtkxeij")
+ .withDisableMetricsCollection("datanlaaxtte")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("dataiksjpkign")
+ .withDisableMetricsCollection("datao")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
.withFormatSettings(new JsonReadSettings().withCompressionProperties(
new CompressionReadSettings().withAdditionalProperties(mapOf("type", "CompressionReadSettings"))))
- .withAdditionalColumns("datamzdnvno");
+ .withAdditionalColumns("dataewrb");
model = BinaryData.fromObject(model).toObject(JsonSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonWriteSettingsTests.java
index 4495927769df..499a265a9dc2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/JsonWriteSettingsTests.java
@@ -11,13 +11,13 @@ public final class JsonWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
JsonWriteSettings model = BinaryData.fromString(
- "{\"type\":\"JsonWriteSettings\",\"filePattern\":\"datayvdjoorbuuhbcckb\",\"\":{\"mdrmasvghphlbk\":\"datae\",\"mviaasdexsrglxlj\":\"datauhmblni\",\"spdipdxq\":\"datayvkkpovz\",\"wvilky\":\"datapdjomddadwosjxy\"}}")
+ "{\"type\":\"JsonWriteSettings\",\"filePattern\":\"databomjby\",\"\":{\"jwfncsaaylcpgzmx\":\"datarkbzra\",\"unntqqguhv\":\"datagppqajdm\",\"fwfuxdtpjcs\":\"datawrziminetb\",\"yfftqombdsgqxa\":\"datakedlclxxq\"}}")
.toObject(JsonWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- JsonWriteSettings model = new JsonWriteSettings().withFilePattern("datayvdjoorbuuhbcckb");
+ JsonWriteSettings model = new JsonWriteSettings().withFilePattern("databomjby");
model = BinaryData.fromObject(model).toObject(JsonWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseReadSettingsTests.java
index b54054791afc..ab44ab05c144 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseReadSettingsTests.java
@@ -11,23 +11,23 @@ public final class LakeHouseReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LakeHouseReadSettings model = BinaryData.fromString(
- "{\"type\":\"LakeHouseReadSettings\",\"recursive\":\"dataambzfxgshaq\",\"wildcardFolderPath\":\"dataeqfniag\",\"wildcardFileName\":\"datayxsoxqa\",\"fileListPath\":\"datatunll\",\"enablePartitionDiscovery\":\"datat\",\"partitionRootPath\":\"dataguuhylzbdimtdohj\",\"deleteFilesAfterCompletion\":\"dataq\",\"modifiedDatetimeStart\":\"datauwcilxznxhbttkk\",\"modifiedDatetimeEnd\":\"dataxjxueilixzjvkqj\",\"maxConcurrentConnections\":\"datablhcmxx\",\"disableMetricsCollection\":\"datankxcljnkmsfsqux\",\"\":{\"ivagcsmrtepsy\":\"dataimnchvkjw\",\"ozys\":\"datadgt\"}}")
+ "{\"type\":\"LakeHouseReadSettings\",\"recursive\":\"datameb\",\"wildcardFolderPath\":\"datain\",\"wildcardFileName\":\"datadk\",\"fileListPath\":\"dataqjj\",\"enablePartitionDiscovery\":\"datah\",\"partitionRootPath\":\"datakcttpcctvcjdrmkn\",\"deleteFilesAfterCompletion\":\"datahvcrjqzbmyftzbx\",\"modifiedDatetimeStart\":\"dataosrb\",\"modifiedDatetimeEnd\":\"datalqn\",\"maxConcurrentConnections\":\"datasegursbzmixw\",\"disableMetricsCollection\":\"datatnkvtzdvxsgdaa\",\"\":{\"xhpqlxnb\":\"datagsuqmrkyaovcbds\",\"aingadkr\":\"dataj\",\"fqmyfgwbuxqzfwg\":\"datanyyjngdfzqc\"}}")
.toObject(LakeHouseReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- LakeHouseReadSettings model = new LakeHouseReadSettings().withMaxConcurrentConnections("datablhcmxx")
- .withDisableMetricsCollection("datankxcljnkmsfsqux")
- .withRecursive("dataambzfxgshaq")
- .withWildcardFolderPath("dataeqfniag")
- .withWildcardFileName("datayxsoxqa")
- .withFileListPath("datatunll")
- .withEnablePartitionDiscovery("datat")
- .withPartitionRootPath("dataguuhylzbdimtdohj")
- .withDeleteFilesAfterCompletion("dataq")
- .withModifiedDatetimeStart("datauwcilxznxhbttkk")
- .withModifiedDatetimeEnd("dataxjxueilixzjvkqj");
+ LakeHouseReadSettings model = new LakeHouseReadSettings().withMaxConcurrentConnections("datasegursbzmixw")
+ .withDisableMetricsCollection("datatnkvtzdvxsgdaa")
+ .withRecursive("datameb")
+ .withWildcardFolderPath("datain")
+ .withWildcardFileName("datadk")
+ .withFileListPath("dataqjj")
+ .withEnablePartitionDiscovery("datah")
+ .withPartitionRootPath("datakcttpcctvcjdrmkn")
+ .withDeleteFilesAfterCompletion("datahvcrjqzbmyftzbx")
+ .withModifiedDatetimeStart("dataosrb")
+ .withModifiedDatetimeEnd("datalqn");
model = BinaryData.fromObject(model).toObject(LakeHouseReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTests.java
index c9aaf79bc0da..d285aa1966c7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTests.java
@@ -19,35 +19,33 @@ public final class LakeHouseTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LakeHouseTableDataset model = BinaryData.fromString(
- "{\"type\":\"LakeHouseTable\",\"typeProperties\":{\"schema\":\"dataeogavfyihuz\",\"table\":\"datapwnyfjcypazwiimd\"},\"description\":\"gkooagr\",\"structure\":\"datapamesi\",\"schema\":\"dataqadewhuwxk\",\"linkedServiceName\":{\"referenceName\":\"xiatfam\",\"parameters\":{\"yfozwhomydxg\":\"dataifllxccprk\",\"zihirqvvketyd\":\"datauqbvfq\",\"rmh\":\"dataaqoktssgvqxer\"}},\"parameters\":{\"jlvihylrxsiy\":{\"type\":\"Bool\",\"defaultValue\":\"datab\"},\"tlqycfvernnk\":{\"type\":\"Object\",\"defaultValue\":\"dataiumt\"}},\"annotations\":[\"dataayqivb\",\"datagdr\",\"datagzetboyztgnmu\",\"datappwp\"],\"folder\":{\"name\":\"grmtgwhzbbdwrjen\"},\"\":{\"onm\":\"dataeiiewibdtpl\"}}")
+ "{\"type\":\"LakeHouseTable\",\"typeProperties\":{\"schema\":\"datairgkn\",\"table\":\"datawla\"},\"description\":\"dajy\",\"structure\":\"databjgipvspe\",\"schema\":\"datazhydt\",\"linkedServiceName\":{\"referenceName\":\"bmtrsdplvia\",\"parameters\":{\"gcneviccwb\":\"datarmawo\",\"oi\":\"dataysclwbjgiynqr\",\"eyydx\":\"dataweofvsxauphzefi\",\"exccwldgfq\":\"datagtiivzkd\"}},\"parameters\":{\"cncrvjcullmfw\":{\"type\":\"SecureString\",\"defaultValue\":\"datatacrsc\"}},\"annotations\":[\"dataeowoszzw\",\"datacsjgfxvc\",\"datamubyguqhgnmsvjfg\",\"datapryyircb\"],\"folder\":{\"name\":\"jrbvyrkbuatxkzn\"},\"\":{\"kevday\":\"datambxo\"}}")
.toObject(LakeHouseTableDataset.class);
- Assertions.assertEquals("gkooagr", model.description());
- Assertions.assertEquals("xiatfam", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("jlvihylrxsiy").type());
- Assertions.assertEquals("grmtgwhzbbdwrjen", model.folder().name());
+ Assertions.assertEquals("dajy", model.description());
+ Assertions.assertEquals("bmtrsdplvia", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("cncrvjcullmfw").type());
+ Assertions.assertEquals("jrbvyrkbuatxkzn", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- LakeHouseTableDataset model
- = new LakeHouseTableDataset().withDescription("gkooagr")
- .withStructure("datapamesi")
- .withSchema("dataqadewhuwxk")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xiatfam")
- .withParameters(mapOf("yfozwhomydxg", "dataifllxccprk", "zihirqvvketyd", "datauqbvfq", "rmh",
- "dataaqoktssgvqxer")))
- .withParameters(mapOf("jlvihylrxsiy",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datab"), "tlqycfvernnk",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataiumt")))
- .withAnnotations(Arrays.asList("dataayqivb", "datagdr", "datagzetboyztgnmu", "datappwp"))
- .withFolder(new DatasetFolder().withName("grmtgwhzbbdwrjen"))
- .withSchemaTypePropertiesSchema("dataeogavfyihuz")
- .withTable("datapwnyfjcypazwiimd");
+ LakeHouseTableDataset model = new LakeHouseTableDataset().withDescription("dajy")
+ .withStructure("databjgipvspe")
+ .withSchema("datazhydt")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bmtrsdplvia")
+ .withParameters(mapOf("gcneviccwb", "datarmawo", "oi", "dataysclwbjgiynqr", "eyydx",
+ "dataweofvsxauphzefi", "exccwldgfq", "datagtiivzkd")))
+ .withParameters(mapOf("cncrvjcullmfw",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datatacrsc")))
+ .withAnnotations(Arrays.asList("dataeowoszzw", "datacsjgfxvc", "datamubyguqhgnmsvjfg", "datapryyircb"))
+ .withFolder(new DatasetFolder().withName("jrbvyrkbuatxkzn"))
+ .withSchemaTypePropertiesSchema("datairgkn")
+ .withTable("datawla");
model = BinaryData.fromObject(model).toObject(LakeHouseTableDataset.class);
- Assertions.assertEquals("gkooagr", model.description());
- Assertions.assertEquals("xiatfam", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("jlvihylrxsiy").type());
- Assertions.assertEquals("grmtgwhzbbdwrjen", model.folder().name());
+ Assertions.assertEquals("dajy", model.description());
+ Assertions.assertEquals("bmtrsdplvia", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("cncrvjcullmfw").type());
+ Assertions.assertEquals("jrbvyrkbuatxkzn", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTypePropertiesTests.java
index 8a840db2a21f..94d53650863f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class LakeHouseTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LakeHouseTableDatasetTypeProperties model
- = BinaryData.fromString("{\"schema\":\"dataokbxxcdk\",\"table\":\"datajwtkftgzl\"}")
+ = BinaryData.fromString("{\"schema\":\"datazkxiym\",\"table\":\"datar\"}")
.toObject(LakeHouseTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
LakeHouseTableDatasetTypeProperties model
- = new LakeHouseTableDatasetTypeProperties().withSchema("dataokbxxcdk").withTable("datajwtkftgzl");
+ = new LakeHouseTableDatasetTypeProperties().withSchema("datazkxiym").withTable("datar");
model = BinaryData.fromObject(model).toObject(LakeHouseTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSinkTests.java
index 5da3adead5d1..d1d6b9fc5cdc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSinkTests.java
@@ -11,21 +11,21 @@ public final class LakeHouseTableSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LakeHouseTableSink model = BinaryData.fromString(
- "{\"type\":\"LakeHouseTableSink\",\"tableActionOption\":\"dataazwebts\",\"partitionOption\":\"dataqkanuxjud\",\"partitionNameList\":\"datazodnxlcdgkc\",\"writeBatchSize\":\"dataancjlkrskzw\",\"writeBatchTimeout\":\"databafqzihmvw\",\"sinkRetryCount\":\"datajwvqiahoqjz\",\"sinkRetryWait\":\"datavwdlrt\",\"maxConcurrentConnections\":\"dataulmzxhgwz\",\"disableMetricsCollection\":\"datastw\",\"\":{\"jssjbpna\":\"dataehn\"}}")
+ "{\"type\":\"LakeHouseTableSink\",\"tableActionOption\":\"dataynkhvpuq\",\"partitionOption\":\"datazdbbitpgrnhpmsdg\",\"partitionNameList\":\"datawfodv\",\"writeBatchSize\":\"dataxmoj\",\"writeBatchTimeout\":\"datavgi\",\"sinkRetryCount\":\"datayevhnqtb\",\"sinkRetryWait\":\"datavjodgplagwvgb\",\"maxConcurrentConnections\":\"datamqudnqc\",\"disableMetricsCollection\":\"databh\",\"\":{\"fzkvrmdoshiyy\":\"datasyszl\"}}")
.toObject(LakeHouseTableSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- LakeHouseTableSink model = new LakeHouseTableSink().withWriteBatchSize("dataancjlkrskzw")
- .withWriteBatchTimeout("databafqzihmvw")
- .withSinkRetryCount("datajwvqiahoqjz")
- .withSinkRetryWait("datavwdlrt")
- .withMaxConcurrentConnections("dataulmzxhgwz")
- .withDisableMetricsCollection("datastw")
- .withTableActionOption("dataazwebts")
- .withPartitionOption("dataqkanuxjud")
- .withPartitionNameList("datazodnxlcdgkc");
+ LakeHouseTableSink model = new LakeHouseTableSink().withWriteBatchSize("dataxmoj")
+ .withWriteBatchTimeout("datavgi")
+ .withSinkRetryCount("datayevhnqtb")
+ .withSinkRetryWait("datavjodgplagwvgb")
+ .withMaxConcurrentConnections("datamqudnqc")
+ .withDisableMetricsCollection("databh")
+ .withTableActionOption("dataynkhvpuq")
+ .withPartitionOption("datazdbbitpgrnhpmsdg")
+ .withPartitionNameList("datawfodv");
model = BinaryData.fromObject(model).toObject(LakeHouseTableSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSourceTests.java
index ebed8bf1ced7..a9a50a34bca1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseTableSourceTests.java
@@ -11,19 +11,19 @@ public final class LakeHouseTableSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LakeHouseTableSource model = BinaryData.fromString(
- "{\"type\":\"LakeHouseTableSource\",\"timestampAsOf\":\"dataddwgozrdglkmgc\",\"versionAsOf\":\"datakrldfoidyhcwc\",\"additionalColumns\":\"datayuusexenywwkdxq\",\"sourceRetryCount\":\"dataysxpaap\",\"sourceRetryWait\":\"datahdqvcifwk\",\"maxConcurrentConnections\":\"dataytvxrtocadtnmqr\",\"disableMetricsCollection\":\"dataecjixcy\",\"\":{\"r\":\"dataii\",\"kvluuessu\":\"databt\",\"sfbkrtpu\":\"datazfrwmctrngjqc\"}}")
+ "{\"type\":\"LakeHouseTableSource\",\"timestampAsOf\":\"datacgg\",\"versionAsOf\":\"dataxbtqizydaiol\",\"additionalColumns\":\"datakghlexvq\",\"sourceRetryCount\":\"datanwmokz\",\"sourceRetryWait\":\"dataltbpqjfoujeiagny\",\"maxConcurrentConnections\":\"datafjssayrwyf\",\"disableMetricsCollection\":\"datatezxr\",\"\":{\"exwhoscinpmvcvnm\":\"datahzwdyvayhvxh\",\"ym\":\"dataqlshg\"}}")
.toObject(LakeHouseTableSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- LakeHouseTableSource model = new LakeHouseTableSource().withSourceRetryCount("dataysxpaap")
- .withSourceRetryWait("datahdqvcifwk")
- .withMaxConcurrentConnections("dataytvxrtocadtnmqr")
- .withDisableMetricsCollection("dataecjixcy")
- .withTimestampAsOf("dataddwgozrdglkmgc")
- .withVersionAsOf("datakrldfoidyhcwc")
- .withAdditionalColumns("datayuusexenywwkdxq");
+ LakeHouseTableSource model = new LakeHouseTableSource().withSourceRetryCount("datanwmokz")
+ .withSourceRetryWait("dataltbpqjfoujeiagny")
+ .withMaxConcurrentConnections("datafjssayrwyf")
+ .withDisableMetricsCollection("datatezxr")
+ .withTimestampAsOf("datacgg")
+ .withVersionAsOf("dataxbtqizydaiol")
+ .withAdditionalColumns("datakghlexvq");
model = BinaryData.fromObject(model).toObject(LakeHouseTableSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseWriteSettingsTests.java
index e0277555fa3f..a62e3f0d81a9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LakeHouseWriteSettingsTests.java
@@ -13,18 +13,18 @@ public final class LakeHouseWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LakeHouseWriteSettings model = BinaryData.fromString(
- "{\"type\":\"LakeHouseWriteSettings\",\"maxConcurrentConnections\":\"datac\",\"disableMetricsCollection\":\"datamjkydhbe\",\"copyBehavior\":\"datavozrdzrik\",\"metadata\":[{\"name\":\"datavvrkxpbjgozoel\",\"value\":\"dataerpbct\"},{\"name\":\"datarvns\",\"value\":\"dataacbrywqqeztlf\"},{\"name\":\"datalgxrsn\",\"value\":\"datarooaahhvsf\"}],\"\":{\"vtx\":\"datakink\",\"njhdkvkqjjouho\":\"datagmebvn\",\"khvcrjqzbmyftz\":\"datakcttpcctvcjdrmkn\",\"fzsegu\":\"dataxfgosrbullq\"}}")
+ "{\"type\":\"LakeHouseWriteSettings\",\"maxConcurrentConnections\":\"datarezpuzkwi\",\"disableMetricsCollection\":\"datafin\",\"copyBehavior\":\"datasdtlpshxjhans\",\"metadata\":[{\"name\":\"datalcnk\",\"value\":\"datasqvfyoksstal\"},{\"name\":\"dataqlxjjltuymnaaqh\",\"value\":\"dataaa\"},{\"name\":\"datadlvccuvcvaf\",\"value\":\"databyjgdjvyclasd\"}],\"\":{\"gsnpv\":\"datanupftek\"}}")
.toObject(LakeHouseWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- LakeHouseWriteSettings model = new LakeHouseWriteSettings().withMaxConcurrentConnections("datac")
- .withDisableMetricsCollection("datamjkydhbe")
- .withCopyBehavior("datavozrdzrik")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datavvrkxpbjgozoel").withValue("dataerpbct"),
- new MetadataItem().withName("datarvns").withValue("dataacbrywqqeztlf"),
- new MetadataItem().withName("datalgxrsn").withValue("datarooaahhvsf")));
+ LakeHouseWriteSettings model = new LakeHouseWriteSettings().withMaxConcurrentConnections("datarezpuzkwi")
+ .withDisableMetricsCollection("datafin")
+ .withCopyBehavior("datasdtlpshxjhans")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datalcnk").withValue("datasqvfyoksstal"),
+ new MetadataItem().withName("dataqlxjjltuymnaaqh").withValue("dataaa"),
+ new MetadataItem().withName("datadlvccuvcvaf").withValue("databyjgdjvyclasd")));
model = BinaryData.fromObject(model).toObject(LakeHouseWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedIntegrationRuntimeTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedIntegrationRuntimeTests.java
index 58000d45ceec..0fd5739c43df 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedIntegrationRuntimeTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedIntegrationRuntimeTests.java
@@ -11,7 +11,7 @@ public final class LinkedIntegrationRuntimeTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LinkedIntegrationRuntime model = BinaryData.fromString(
- "{\"name\":\"mfwxmcxh\",\"subscriptionId\":\"g\",\"dataFactoryName\":\"ifoyoc\",\"dataFactoryLocation\":\"adhmqyufpfowwey\",\"createTime\":\"2021-04-21T05:51:44Z\"}")
+ "{\"name\":\"vdulymkgj\",\"subscriptionId\":\"yhxfgha\",\"dataFactoryName\":\"pftkgmbmvxbiubz\",\"dataFactoryLocation\":\"psotbame\",\"createTime\":\"2021-05-30T00:05:33Z\"}")
.toObject(LinkedIntegrationRuntime.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesCreateOrUpdateWithResponseMockTests.java
index 0132f4f4c3bc..9152e3b276a6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesCreateOrUpdateWithResponseMockTests.java
@@ -28,7 +28,7 @@ public final class LinkedServicesCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"LinkedService\",\"version\":\"fnlksyqpkskbidmz\",\"connectVia\":{\"referenceName\":\"pbhcgesbteqfen\",\"parameters\":{\"gesflnzibguw\":\"datatcy\"}},\"description\":\"hxa\",\"parameters\":{\"cillfq\":{\"type\":\"Array\",\"defaultValue\":\"datafjpefirjkinofw\"}},\"annotations\":[\"dataifdrbkprblw\",\"databjse\",\"dataqqts\",\"dataupogtrwkuwn\"],\"\":{\"wngtiyzzi\":\"datajeo\",\"nrky\":\"datauovgipqgtsgo\",\"qoiqonnvaybo\":\"datahtcrxcnuyfvrid\",\"pojbifixdgkvlze\":\"databigzlvqmy\"}},\"name\":\"qopwabrzrhdezlhs\",\"type\":\"pdbol\",\"etag\":\"hyqdvxqoajfoscd\",\"id\":\"fatf\"}";
+ = "{\"properties\":{\"type\":\"LinkedService\",\"version\":\"awfujvgvrpear\",\"connectVia\":{\"referenceName\":\"hppupucybtr\",\"parameters\":{\"m\":\"datalc\",\"xex\":\"datarho\",\"zmqdnfonncnf\":\"dataaexweeifog\",\"arx\":\"datayggiomgv\"}},\"description\":\"tmjygnixkpadjqj\",\"parameters\":{\"n\":{\"type\":\"Array\",\"defaultValue\":\"dataibucmfvuizjrs\"},\"wuzwydsvgonkomua\":{\"type\":\"SecureString\",\"defaultValue\":\"dataezxldmz\"},\"qvul\":{\"type\":\"SecureString\",\"defaultValue\":\"datakwiytg\"},\"vxfyqsfy\":{\"type\":\"Array\",\"defaultValue\":\"datajdbcypv\"}},\"annotations\":[\"datahbfpzfvqlmzpc\",\"datax\",\"datacslmyrsojqpjba\",\"datafnxdi\"],\"\":{\"c\":\"dataulvmval\",\"fcexbtwic\":\"datahysphdhtcop\",\"e\":\"datahx\",\"kuemotgkyfh\":\"datagkvmmkwa\"}},\"name\":\"mwqkfsvzczisiqns\",\"type\":\"wjfuhq\",\"etag\":\"tdnufvzxosrstev\",\"id\":\"ssaubmdoji\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -38,27 +38,31 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
LinkedServiceResource response = manager.linkedServices()
- .define("qighnunptjm")
- .withExistingFactory("wgakghvaqbk", "zmwbxautspnyutf")
- .withProperties(new LinkedService().withVersion("irjnddaovgiowmzt")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("nncvj")
- .withParameters(mapOf("xxmsiblieg", "dataucqx", "yclv", "datajktfsci")))
- .withDescription("vsag")
- .withParameters(mapOf("lcqjnwvqif",
+ .define("gafznzemis")
+ .withExistingFactory("oxjqysfejddi", "gwckvoxlih")
+ .withProperties(new LinkedService().withVersion("nxwosanch")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("uvtbptdeumlfszx")
+ .withParameters(mapOf("nkeodgpqdcrnubnt", "datab", "wcsgczvui", "datawohtuiwsnccmunh", "xzdayzfuv",
+ "datarngney")))
+ .withDescription("elmimmcc")
+ .withParameters(mapOf("tevafczgise",
new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("datarqnwoahfa"),
- "qivvpvuy",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datafsvrjdpzvhxssn")))
- .withAnnotations(Arrays.asList("datamdinnisuuakaadb"))
+ .withDefaultValue("dataecgeregfthgjmzn"),
+ "wg",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataiynlcdqxownbj"),
+ "xsfe", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datawkazmw"),
+ "ityqqosw",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datacgcfjno")))
+ .withAnnotations(Arrays.asList("datatgfewflxbyyv"))
.withAdditionalProperties(mapOf("type", "LinkedService")))
- .withIfMatch("vw")
+ .withIfMatch("jrh")
.create();
- Assertions.assertEquals("fatf", response.id());
- Assertions.assertEquals("fnlksyqpkskbidmz", response.properties().version());
- Assertions.assertEquals("pbhcgesbteqfen", response.properties().connectVia().referenceName());
- Assertions.assertEquals("hxa", response.properties().description());
- Assertions.assertEquals(ParameterType.ARRAY, response.properties().parameters().get("cillfq").type());
+ Assertions.assertEquals("ssaubmdoji", response.id());
+ Assertions.assertEquals("awfujvgvrpear", response.properties().version());
+ Assertions.assertEquals("hppupucybtr", response.properties().connectVia().referenceName());
+ Assertions.assertEquals("tmjygnixkpadjqj", response.properties().description());
+ Assertions.assertEquals(ParameterType.ARRAY, response.properties().parameters().get("n").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesDeleteWithResponseMockTests.java
index a3276b1562da..77eda620ff33 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesDeleteWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.linkedServices()
- .deleteWithResponse("wkphiqjegeafg", "qglljcblppn", "osnvcwj", com.azure.core.util.Context.NONE);
+ .deleteWithResponse("vlttoplxbxf", "liyikcnlb", "hxo", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesGetWithResponseMockTests.java
index 114953a844d5..7bec5031cafd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesGetWithResponseMockTests.java
@@ -22,7 +22,7 @@ public final class LinkedServicesGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"LinkedService\",\"version\":\"dfvd\",\"connectVia\":{\"referenceName\":\"b\",\"parameters\":{\"dad\":\"databvyuarbycuux\",\"ugmfersbktrei\":\"datalilkmptvmtn\",\"gjrkuepr\":\"datalszpusb\"}},\"description\":\"zbfoldbbli\",\"parameters\":{\"vqbnzrrkmanr\":{\"type\":\"Bool\",\"defaultValue\":\"datapvmaywpra\"},\"keseazgf\":{\"type\":\"Int\",\"defaultValue\":\"dataqojxyabvvbsilah\"}},\"annotations\":[\"datassi\",\"dataelbtgexiwcqeihuy\",\"datazidoyvquufplm\"],\"\":{\"otpvoehs\":\"datazbtrf\"}},\"name\":\"rao\",\"type\":\"r\",\"etag\":\"wdgzfqsreyui\",\"id\":\"rr\"}";
+ = "{\"properties\":{\"type\":\"LinkedService\",\"version\":\"uovkgqtzghtj\",\"connectVia\":{\"referenceName\":\"zywoqmpgvxi\",\"parameters\":{\"qzqdco\":\"datasvykthxudowjwlte\",\"nzsjoxuogyak\":\"datasqufsyih\",\"mngstvn\":\"dataxjzalhun\",\"yinxxgxncoai\":\"datashaulltvlylbo\"}},\"description\":\"l\",\"parameters\":{\"qyeiohanxliojod\":{\"type\":\"Float\",\"defaultValue\":\"datazytaocxak\"}},\"annotations\":[\"databcu\",\"datax\"],\"\":{\"ukxkvgu\":\"dataww\",\"jfrta\":\"datafr\"}},\"name\":\"rxxvzqineqm\",\"type\":\"dvknxjtttk\",\"etag\":\"hqucasfqodcxvd\",\"id\":\"kjghlcfoaabl\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,13 +32,13 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
LinkedServiceResource response = manager.linkedServices()
- .getWithResponse("frisreh", "yfi", "lpiqei", "jboghjdihtc", com.azure.core.util.Context.NONE)
+ .getWithResponse("z", "ufr", "ewqwdglmfsjpl", "dhzltmywy", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("rr", response.id());
- Assertions.assertEquals("dfvd", response.properties().version());
- Assertions.assertEquals("b", response.properties().connectVia().referenceName());
- Assertions.assertEquals("zbfoldbbli", response.properties().description());
- Assertions.assertEquals(ParameterType.BOOL, response.properties().parameters().get("vqbnzrrkmanr").type());
+ Assertions.assertEquals("kjghlcfoaabl", response.id());
+ Assertions.assertEquals("uovkgqtzghtj", response.properties().version());
+ Assertions.assertEquals("zywoqmpgvxi", response.properties().connectVia().referenceName());
+ Assertions.assertEquals("l", response.properties().description());
+ Assertions.assertEquals(ParameterType.FLOAT, response.properties().parameters().get("qyeiohanxliojod").type());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesListByFactoryMockTests.java
index baed706b5145..8f795295d762 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LinkedServicesListByFactoryMockTests.java
@@ -23,7 +23,7 @@ public final class LinkedServicesListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"type\":\"LinkedService\",\"version\":\"ubsidwgya\",\"connectVia\":{\"referenceName\":\"pefs\",\"parameters\":{\"fhsckecume\":\"datadcmjfieydtnpqtwo\",\"koaxstqqjqliyxze\":\"datagoaxtwtkkmuir\",\"oiaotaaxluovzm\":\"dataiiudnmojjmimy\",\"ltblm\":\"datajirp\"}},\"description\":\"bafcmsotudnkr\",\"parameters\":{\"eel\":{\"type\":\"Int\",\"defaultValue\":\"dataqeiguxix\"}},\"annotations\":[\"datavinumd\"],\"\":{\"rn\":\"datayvz\",\"obagaigtpjjz\":\"datakany\",\"wd\":\"dataqolmoifxli\"}},\"name\":\"qxqjvjubjqjxobm\",\"type\":\"jtzatr\",\"etag\":\"rneugbupkjyosq\",\"id\":\"xedkkdk\"}]}";
+ = "{\"value\":[{\"properties\":{\"type\":\"LinkedService\",\"version\":\"sgpymzrt\",\"connectVia\":{\"referenceName\":\"jn\",\"parameters\":{\"hoiufrqsm\":\"datasjbnnuqsz\"}},\"description\":\"ddbunxufataqsf\",\"parameters\":{\"mmbu\":{\"type\":\"Bool\",\"defaultValue\":\"datahacu\"},\"qwisuhare\":{\"type\":\"Float\",\"defaultValue\":\"datalivvnyzc\"},\"yuxcjqyfx\":{\"type\":\"SecureString\",\"defaultValue\":\"dataadvvgndfyelpnlpn\"},\"ygecly\":{\"type\":\"Int\",\"defaultValue\":\"datatukossiflfv\"}},\"annotations\":[\"datashkzibbjbzdnkgp\",\"databvicwfrybvhg\",\"dataltjghdfusphokcc\",\"dataynnm\"],\"\":{\"hpxxwbetmqugov\":\"dataqii\",\"qrgjejabqvg\":\"dataddxlrbs\",\"qyazpxlyabjrzgss\":\"datah\"}},\"name\":\"wurhkuxphbwmb\",\"type\":\"gm\",\"etag\":\"l\",\"id\":\"nkylqdsyg\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -33,13 +33,13 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.linkedServices().listByFactory("grcjoycqndgbxtz", "teszohntch", com.azure.core.util.Context.NONE);
+ = manager.linkedServices().listByFactory("lieyyfqhndj", "yovuyxccrajx", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("xedkkdk", response.iterator().next().id());
- Assertions.assertEquals("ubsidwgya", response.iterator().next().properties().version());
- Assertions.assertEquals("pefs", response.iterator().next().properties().connectVia().referenceName());
- Assertions.assertEquals("bafcmsotudnkr", response.iterator().next().properties().description());
- Assertions.assertEquals(ParameterType.INT,
- response.iterator().next().properties().parameters().get("eel").type());
+ Assertions.assertEquals("nkylqdsyg", response.iterator().next().id());
+ Assertions.assertEquals("sgpymzrt", response.iterator().next().properties().version());
+ Assertions.assertEquals("jn", response.iterator().next().properties().connectVia().referenceName());
+ Assertions.assertEquals("ddbunxufataqsf", response.iterator().next().properties().description());
+ Assertions.assertEquals(ParameterType.BOOL,
+ response.iterator().next().properties().parameters().get("mmbu").type());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogLocationSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogLocationSettingsTests.java
index 96c2911d6ddb..f20c95b3e5e0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogLocationSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogLocationSettingsTests.java
@@ -15,19 +15,19 @@ public final class LogLocationSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LogLocationSettings model = BinaryData.fromString(
- "{\"linkedServiceName\":{\"referenceName\":\"dmdpndouylf\",\"parameters\":{\"zassrs\":\"dataqinaokxouknzh\"}},\"path\":\"datauknbtxt\"}")
+ "{\"linkedServiceName\":{\"referenceName\":\"dwocufcsh\",\"parameters\":{\"x\":\"datalc\",\"k\":\"dataofwqdro\",\"vgjm\":\"dataegilbkzctqbvntl\"}},\"path\":\"dataqoy\"}")
.toObject(LogLocationSettings.class);
- Assertions.assertEquals("dmdpndouylf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("dwocufcsh", model.linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
LogLocationSettings model = new LogLocationSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dmdpndouylf")
- .withParameters(mapOf("zassrs", "dataqinaokxouknzh")))
- .withPath("datauknbtxt");
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dwocufcsh")
+ .withParameters(mapOf("x", "datalc", "k", "dataofwqdro", "vgjm", "dataegilbkzctqbvntl")))
+ .withPath("dataqoy");
model = BinaryData.fromObject(model).toObject(LogLocationSettings.class);
- Assertions.assertEquals("dmdpndouylf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("dwocufcsh", model.linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogSettingsTests.java
index 88d7db832be4..f70b72b92859 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogSettingsTests.java
@@ -17,26 +17,26 @@ public final class LogSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LogSettings model = BinaryData.fromString(
- "{\"enableCopyActivityLog\":\"datawnxry\",\"copyActivityLogSettings\":{\"logLevel\":\"datajcrpaxwx\",\"enableReliableLogging\":\"dataxsetvdzidldmxfqf\"},\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"ywbbanzhdciu\",\"parameters\":{\"hop\":\"databvflgkkiu\",\"rtaevq\":\"datafobpyeo\",\"owsmrvdtqhr\":\"datafdhpkiiunyrobcke\"}},\"path\":\"dataqs\"}}")
+ "{\"enableCopyActivityLog\":\"datajzpvckhbutmxtijs\",\"copyActivityLogSettings\":{\"logLevel\":\"datadpwljtwibwcdx\",\"enableReliableLogging\":\"datans\"},\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"xqtmhf\",\"parameters\":{\"xmgghutlhszz\":\"datanvrdtdl\",\"pbiuwnxhqeljmf\":\"datajyogcpwne\",\"dhg\":\"datalqdikuvjcls\",\"kiw\":\"datakflwnlpbawtpw\"}},\"path\":\"dataplqnilozf\"}}")
.toObject(LogSettings.class);
- Assertions.assertEquals("ywbbanzhdciu", model.logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("xqtmhf", model.logLocationSettings().linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- LogSettings model
- = new LogSettings().withEnableCopyActivityLog("datawnxry")
- .withCopyActivityLogSettings(new CopyActivityLogSettings().withLogLevel("datajcrpaxwx")
- .withEnableReliableLogging("dataxsetvdzidldmxfqf"))
- .withLogLocationSettings(
- new LogLocationSettings()
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("ywbbanzhdciu")
- .withParameters(mapOf("hop", "databvflgkkiu", "rtaevq", "datafobpyeo", "owsmrvdtqhr",
- "datafdhpkiiunyrobcke")))
- .withPath("dataqs"));
+ LogSettings model = new LogSettings().withEnableCopyActivityLog("datajzpvckhbutmxtijs")
+ .withCopyActivityLogSettings(
+ new CopyActivityLogSettings().withLogLevel("datadpwljtwibwcdx").withEnableReliableLogging("datans"))
+ .withLogLocationSettings(
+ new LogLocationSettings()
+ .withLinkedServiceName(
+ new LinkedServiceReference()
+ .withReferenceName("xqtmhf")
+ .withParameters(mapOf("xmgghutlhszz", "datanvrdtdl", "pbiuwnxhqeljmf", "datajyogcpwne",
+ "dhg", "datalqdikuvjcls", "kiw", "datakflwnlpbawtpw")))
+ .withPath("dataplqnilozf"));
model = BinaryData.fromObject(model).toObject(LogSettings.class);
- Assertions.assertEquals("ywbbanzhdciu", model.logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals("xqtmhf", model.logLocationSettings().linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogStorageSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogStorageSettingsTests.java
index 293e30d1f36f..acf680f4bcc4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogStorageSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LogStorageSettingsTests.java
@@ -15,22 +15,22 @@ public final class LogStorageSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LogStorageSettings model = BinaryData.fromString(
- "{\"linkedServiceName\":{\"referenceName\":\"hmjsqcubyj\",\"parameters\":{\"ecsft\":\"datalliteenah\",\"jh\":\"datasubzfuhjnmdcyrbz\"}},\"path\":\"datavtzdxtwyxpkww\",\"logLevel\":\"datakvdevdvkeyqx\",\"enableReliableLogging\":\"datahdnlxeiluexvm\",\"\":{\"jwtalbqkg\":\"dataqpsqpf\",\"iqtz\":\"datachdyxrjjdji\",\"ddkujvqzcuqc\":\"datab\"}}")
+ "{\"linkedServiceName\":{\"referenceName\":\"tnprnshln\",\"parameters\":{\"bltjyis\":\"datavlzgsqwiub\",\"i\":\"datascuwyluktzcuxux\"}},\"path\":\"dataeguxrziryxr\",\"logLevel\":\"datarutmxqvvepofts\",\"enableReliableLogging\":\"datafwusfbrnjvzl\",\"\":{\"bieuqfgkf\":\"datajempvubslwzn\",\"kpswwutduchcfn\":\"dataftgbupu\"}}")
.toObject(LogStorageSettings.class);
- Assertions.assertEquals("hmjsqcubyj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("tnprnshln", model.linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
LogStorageSettings model = new LogStorageSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hmjsqcubyj")
- .withParameters(mapOf("ecsft", "datalliteenah", "jh", "datasubzfuhjnmdcyrbz")))
- .withPath("datavtzdxtwyxpkww")
- .withLogLevel("datakvdevdvkeyqx")
- .withEnableReliableLogging("datahdnlxeiluexvm")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tnprnshln")
+ .withParameters(mapOf("bltjyis", "datavlzgsqwiub", "i", "datascuwyluktzcuxux")))
+ .withPath("dataeguxrziryxr")
+ .withLogLevel("datarutmxqvvepofts")
+ .withEnableReliableLogging("datafwusfbrnjvzl")
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(LogStorageSettings.class);
- Assertions.assertEquals("hmjsqcubyj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("tnprnshln", model.linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTests.java
index 190502fbddcc..d23ac5633ca3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTests.java
@@ -24,72 +24,72 @@ public final class LookupActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LookupActivity model = BinaryData.fromString(
- "{\"type\":\"Lookup\",\"typeProperties\":{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"datasmnelqlqnwv\",\"sourceRetryWait\":\"dataxzdimnfnrpq\",\"maxConcurrentConnections\":\"datazgncyksblre\",\"disableMetricsCollection\":\"datawak\",\"\":{\"lwqhzyrugst\":\"dataiylkfnedxdemcyr\",\"ugkttlpw\":\"datazpozqluu\",\"lqdotqe\":\"dataolajevww\",\"jbbwftcnz\":\"datauenteucao\"}},\"dataset\":{\"referenceName\":\"kdademqptxekmdk\",\"parameters\":{\"lppnevujkzb\":\"dataupmlayejocsqtibu\",\"fajygnhmoeoxs\":\"datakgvwkdgsrtm\",\"z\":\"databl\"}},\"firstRowOnly\":\"datacxygpmj\"},\"linkedServiceName\":{\"referenceName\":\"mtxfaucihqs\",\"parameters\":{\"oacnlyzi\":\"dataq\",\"xiwfkdblvbwuey\":\"datawtqvgpidrtb\"}},\"policy\":{\"timeout\":\"dataujvmnooagaqnekwe\",\"retry\":\"datampiql\",\"retryIntervalInSeconds\":1187162100,\"secureInput\":false,\"secureOutput\":true,\"\":{\"hcpsuf\":\"datamhvjogv\"}},\"name\":\"dgcvfxsvxk\",\"description\":\"hkhwqwvw\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"wlenrcovq\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"gzslnnc\":\"datactkrgagxzmrxx\",\"vni\":\"datawrhoma\"}},{\"activity\":\"up\",\"dependencyConditions\":[\"Skipped\",\"Completed\"],\"\":{\"kqvkdpnqcuprl\":\"datayetfxyx\",\"ovsqmzee\":\"datazfafekcu\",\"fgkbytzmnamesdcm\":\"dataitqvqyinifnmc\"}},{\"activity\":\"mv\",\"dependencyConditions\":[\"Failed\"],\"\":{\"vaap\":\"datahyrh\",\"uj\":\"datagyyufhcfeggy\"}}],\"userProperties\":[{\"name\":\"vazqsbrqspvl\",\"value\":\"datauxvujuxvl\"},{\"name\":\"x\",\"value\":\"dataftcinj\"},{\"name\":\"rayoask\",\"value\":\"datallqweoobbngym\"}],\"\":{\"wtzxq\":\"dataw\",\"pwvhiaxkm\":\"dataqzplzyjktc\",\"fhlwgka\":\"dataitczuscqobujfx\",\"kmbdhcc\":\"dataxp\"}}")
+ "{\"type\":\"Lookup\",\"typeProperties\":{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"datawftcnzo\",\"sourceRetryWait\":\"dataa\",\"maxConcurrentConnections\":\"datamqpt\",\"disableMetricsCollection\":\"datakmdkbtmupmla\",\"\":{\"tibuflppn\":\"dataocs\",\"kgvwkdgsrtm\":\"datavujkzb\"}},\"dataset\":{\"referenceName\":\"fajygnhmoeoxs\",\"parameters\":{\"xfaucihqsogt\":\"datajzodcxygpmjfwm\",\"cnly\":\"dataao\",\"xiwfkdblvbwuey\":\"dataizwtqvgpidrtb\"}},\"firstRowOnly\":\"datal\"},\"linkedServiceName\":{\"referenceName\":\"v\",\"parameters\":{\"xmpiqlnwfbj\":\"dataoagaqnekwe\",\"psufcdgcvfxsvxk\":\"datahxsmhvjogvqh\",\"wlenrcovq\":\"datayhkhwqwvwfombcg\"}},\"policy\":{\"timeout\":\"datafyc\",\"retry\":\"datargagxzmrxx\",\"retryIntervalInSeconds\":494364845,\"secureInput\":false,\"secureOutput\":true,\"\":{\"vni\":\"datawrhoma\",\"oneoqy\":\"dataup\"}},\"name\":\"tfx\",\"description\":\"skqvkdpnqcuprl\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"cue\",\"dependencyConditions\":[\"Completed\",\"Failed\"],\"\":{\"tqvqyinifnmccf\":\"dataeel\",\"y\":\"datak\",\"vatnfdhyrhfvaap\":\"datazmnamesdcmg\",\"uj\":\"datagyyufhcfeggy\"}},{\"activity\":\"bdvazqsbrqspvltu\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Skipped\"],\"\":{\"injc\":\"datallxeft\"}}],\"userProperties\":[{\"name\":\"oaskul\",\"value\":\"dataqweoob\"},{\"name\":\"ngymbzawdwtzx\",\"value\":\"databqzplzyjktc\"},{\"name\":\"pwvhiaxkm\",\"value\":\"dataitczuscqobujfx\"}],\"\":{\"mjotccbduwswfb\":\"datalwgkaaxpwkmbdhc\",\"ubmeih\":\"datay\"}}")
.toObject(LookupActivity.class);
- Assertions.assertEquals("dgcvfxsvxk", model.name());
- Assertions.assertEquals("hkhwqwvw", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("wlenrcovq", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("vazqsbrqspvl", model.userProperties().get(0).name());
- Assertions.assertEquals("mtxfaucihqs", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1187162100, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("tfx", model.name());
+ Assertions.assertEquals("skqvkdpnqcuprl", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
+ Assertions.assertEquals("cue", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("oaskul", model.userProperties().get(0).name());
+ Assertions.assertEquals("v", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(494364845, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
- Assertions.assertEquals("kdademqptxekmdk", model.dataset().referenceName());
+ Assertions.assertEquals("fajygnhmoeoxs", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- LookupActivity model = new LookupActivity().withName("dgcvfxsvxk")
- .withDescription("hkhwqwvw")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("wlenrcovq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("up")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("mv")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("vazqsbrqspvl").withValue("datauxvujuxvl"),
- new UserProperty().withName("x").withValue("dataftcinj"),
- new UserProperty().withName("rayoask").withValue("datallqweoobbngym")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mtxfaucihqs")
- .withParameters(mapOf("oacnlyzi", "dataq", "xiwfkdblvbwuey", "datawtqvgpidrtb")))
- .withPolicy(new ActivityPolicy().withTimeout("dataujvmnooagaqnekwe")
- .withRetry("datampiql")
- .withRetryIntervalInSeconds(1187162100)
- .withSecureInput(false)
- .withSecureOutput(true)
- .withAdditionalProperties(mapOf()))
- .withSource(new CopySource().withSourceRetryCount("datasmnelqlqnwv")
- .withSourceRetryWait("dataxzdimnfnrpq")
- .withMaxConcurrentConnections("datazgncyksblre")
- .withDisableMetricsCollection("datawak")
- .withAdditionalProperties(mapOf("type", "CopySource")))
- .withDataset(
- new DatasetReference().withReferenceName("kdademqptxekmdk")
- .withParameters(mapOf("lppnevujkzb", "dataupmlayejocsqtibu", "fajygnhmoeoxs", "datakgvwkdgsrtm",
- "z", "databl")))
- .withFirstRowOnly("datacxygpmj");
+ LookupActivity model
+ = new LookupActivity().withName("tfx")
+ .withDescription("skqvkdpnqcuprl")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("cue")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("bdvazqsbrqspvltu")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED,
+ DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("oaskul").withValue("dataqweoob"),
+ new UserProperty().withName("ngymbzawdwtzx").withValue("databqzplzyjktc"),
+ new UserProperty().withName("pwvhiaxkm").withValue("dataitczuscqobujfx")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("v")
+ .withParameters(mapOf("xmpiqlnwfbj", "dataoagaqnekwe", "psufcdgcvfxsvxk", "datahxsmhvjogvqh",
+ "wlenrcovq", "datayhkhwqwvwfombcg")))
+ .withPolicy(new ActivityPolicy().withTimeout("datafyc")
+ .withRetry("datargagxzmrxx")
+ .withRetryIntervalInSeconds(494364845)
+ .withSecureInput(false)
+ .withSecureOutput(true)
+ .withAdditionalProperties(mapOf()))
+ .withSource(new CopySource().withSourceRetryCount("datawftcnzo")
+ .withSourceRetryWait("dataa")
+ .withMaxConcurrentConnections("datamqpt")
+ .withDisableMetricsCollection("datakmdkbtmupmla")
+ .withAdditionalProperties(mapOf("type", "CopySource")))
+ .withDataset(new DatasetReference().withReferenceName("fajygnhmoeoxs")
+ .withParameters(mapOf("xfaucihqsogt", "datajzodcxygpmjfwm", "cnly", "dataao", "xiwfkdblvbwuey",
+ "dataizwtqvgpidrtb")))
+ .withFirstRowOnly("datal");
model = BinaryData.fromObject(model).toObject(LookupActivity.class);
- Assertions.assertEquals("dgcvfxsvxk", model.name());
- Assertions.assertEquals("hkhwqwvw", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("wlenrcovq", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("vazqsbrqspvl", model.userProperties().get(0).name());
- Assertions.assertEquals("mtxfaucihqs", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1187162100, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("tfx", model.name());
+ Assertions.assertEquals("skqvkdpnqcuprl", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
+ Assertions.assertEquals("cue", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("oaskul", model.userProperties().get(0).name());
+ Assertions.assertEquals("v", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(494364845, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
- Assertions.assertEquals("kdademqptxekmdk", model.dataset().referenceName());
+ Assertions.assertEquals("fajygnhmoeoxs", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTypePropertiesTests.java
index 8d1e4bff598d..10513d5d707d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/LookupActivityTypePropertiesTests.java
@@ -16,25 +16,25 @@ public final class LookupActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
LookupActivityTypeProperties model = BinaryData.fromString(
- "{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"dataotccbdu\",\"sourceRetryWait\":\"datawfbqycubmeihagm\",\"maxConcurrentConnections\":\"datadmlkxwc\",\"disableMetricsCollection\":\"datalbiptsf\",\"\":{\"o\":\"dataaobuimfdaqunje\",\"eablknqnqqcgi\":\"dataegmazd\"}},\"dataset\":{\"referenceName\":\"ffdeogm\",\"parameters\":{\"po\":\"dataopjlgtcswqxeva\",\"gn\":\"datamxtcnmocskpgn\",\"dezm\":\"dataguqfnhmmvedj\"}},\"firstRowOnly\":\"databezlucxbu\"}")
+ "{\"source\":{\"type\":\"CopySource\",\"sourceRetryCount\":\"datamewdm\",\"sourceRetryWait\":\"dataxw\",\"maxConcurrentConnections\":\"dataslbi\",\"disableMetricsCollection\":\"datas\",\"\":{\"mfdaqunjegomegma\":\"datawaobu\",\"lknqnqqcg\":\"datadgea\",\"gtcswqx\":\"datayffdeogmwlpopj\"}},\"dataset\":{\"referenceName\":\"vaz\",\"parameters\":{\"gn\":\"datamxtcnmocskpgn\",\"dezm\":\"dataguqfnhmmvedj\",\"flm\":\"datapbezlucxbuda\",\"i\":\"datavbwrunrgmyv\"}},\"firstRowOnly\":\"dataxlhfmkllxoahfv\"}")
.toObject(LookupActivityTypeProperties.class);
- Assertions.assertEquals("ffdeogm", model.dataset().referenceName());
+ Assertions.assertEquals("vaz", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
LookupActivityTypeProperties model = new LookupActivityTypeProperties()
- .withSource(new CopySource().withSourceRetryCount("dataotccbdu")
- .withSourceRetryWait("datawfbqycubmeihagm")
- .withMaxConcurrentConnections("datadmlkxwc")
- .withDisableMetricsCollection("datalbiptsf")
+ .withSource(new CopySource().withSourceRetryCount("datamewdm")
+ .withSourceRetryWait("dataxw")
+ .withMaxConcurrentConnections("dataslbi")
+ .withDisableMetricsCollection("datas")
.withAdditionalProperties(mapOf("type", "CopySource")))
- .withDataset(new DatasetReference().withReferenceName("ffdeogm")
- .withParameters(
- mapOf("po", "dataopjlgtcswqxeva", "gn", "datamxtcnmocskpgn", "dezm", "dataguqfnhmmvedj")))
- .withFirstRowOnly("databezlucxbu");
+ .withDataset(new DatasetReference().withReferenceName("vaz")
+ .withParameters(mapOf("gn", "datamxtcnmocskpgn", "dezm", "dataguqfnhmmvedj", "flm", "datapbezlucxbuda",
+ "i", "datavbwrunrgmyv")))
+ .withFirstRowOnly("dataxlhfmkllxoahfv");
model = BinaryData.fromObject(model).toObject(LookupActivityTypeProperties.class);
- Assertions.assertEquals("ffdeogm", model.dataset().referenceName());
+ Assertions.assertEquals("vaz", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoObjectDatasetTests.java
index 895812bee1df..9f371746a9ad 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoObjectDatasetTests.java
@@ -19,34 +19,31 @@ public final class MagentoObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MagentoObjectDataset model = BinaryData.fromString(
- "{\"type\":\"MagentoObject\",\"typeProperties\":{\"tableName\":\"datagfb\"},\"description\":\"kxasomafe\",\"structure\":\"dataz\",\"schema\":\"datardxpcpautfzptr\",\"linkedServiceName\":{\"referenceName\":\"dzytrtffvp\",\"parameters\":{\"oqatdjka\":\"datacyuwenbqvpraw\"}},\"parameters\":{\"xfzynfemq\":{\"type\":\"SecureString\",\"defaultValue\":\"datacs\"},\"uup\":{\"type\":\"SecureString\",\"defaultValue\":\"datakpgwgssd\"},\"pvirzyud\":{\"type\":\"Int\",\"defaultValue\":\"databnlqyvdsqxkjwd\"}},\"annotations\":[\"dataxrxhxmlfouqp\"],\"folder\":{\"name\":\"andbp\"},\"\":{\"jxcqcaczzvwaeztt\":\"datah\",\"qlyyslg\":\"datajqyfy\",\"bdsvkllrzhshhkb\":\"dataf\",\"rgfwhfzh\":\"datahcazkgdjth\"}}")
+ "{\"type\":\"MagentoObject\",\"typeProperties\":{\"tableName\":\"datasvkllrz\"},\"description\":\"hhkbc\",\"structure\":\"dataazk\",\"schema\":\"datajthprgfwhfzhhr\",\"linkedServiceName\":{\"referenceName\":\"rmrfyyqjcni\",\"parameters\":{\"ztqe\":\"datarsddcuqddldaoyv\",\"zzw\":\"dataqjojesxjht\"}},\"parameters\":{\"guzlweoyxfoaf\":{\"type\":\"Array\",\"defaultValue\":\"dataoyineuaxpmezit\"}},\"annotations\":[\"datapzlx\"],\"folder\":{\"name\":\"dhgwhlbpjuaj\"},\"\":{\"svdtyydd\":\"dataavmitnwlyhbuj\"}}")
.toObject(MagentoObjectDataset.class);
- Assertions.assertEquals("kxasomafe", model.description());
- Assertions.assertEquals("dzytrtffvp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("xfzynfemq").type());
- Assertions.assertEquals("andbp", model.folder().name());
+ Assertions.assertEquals("hhkbc", model.description());
+ Assertions.assertEquals("rmrfyyqjcni", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("guzlweoyxfoaf").type());
+ Assertions.assertEquals("dhgwhlbpjuaj", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MagentoObjectDataset model = new MagentoObjectDataset().withDescription("kxasomafe")
- .withStructure("dataz")
- .withSchema("datardxpcpautfzptr")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dzytrtffvp")
- .withParameters(mapOf("oqatdjka", "datacyuwenbqvpraw")))
- .withParameters(mapOf("xfzynfemq",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datacs"), "uup",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datakpgwgssd"),
- "pvirzyud",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("databnlqyvdsqxkjwd")))
- .withAnnotations(Arrays.asList("dataxrxhxmlfouqp"))
- .withFolder(new DatasetFolder().withName("andbp"))
- .withTableName("datagfb");
+ MagentoObjectDataset model = new MagentoObjectDataset().withDescription("hhkbc")
+ .withStructure("dataazk")
+ .withSchema("datajthprgfwhfzhhr")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rmrfyyqjcni")
+ .withParameters(mapOf("ztqe", "datarsddcuqddldaoyv", "zzw", "dataqjojesxjht")))
+ .withParameters(mapOf("guzlweoyxfoaf",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataoyineuaxpmezit")))
+ .withAnnotations(Arrays.asList("datapzlx"))
+ .withFolder(new DatasetFolder().withName("dhgwhlbpjuaj"))
+ .withTableName("datasvkllrz");
model = BinaryData.fromObject(model).toObject(MagentoObjectDataset.class);
- Assertions.assertEquals("kxasomafe", model.description());
- Assertions.assertEquals("dzytrtffvp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("xfzynfemq").type());
- Assertions.assertEquals("andbp", model.folder().name());
+ Assertions.assertEquals("hhkbc", model.description());
+ Assertions.assertEquals("rmrfyyqjcni", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("guzlweoyxfoaf").type());
+ Assertions.assertEquals("dhgwhlbpjuaj", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoSourceTests.java
index 631d62c5827c..28f6ed14aab4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MagentoSourceTests.java
@@ -11,19 +11,19 @@ public final class MagentoSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MagentoSource model = BinaryData.fromString(
- "{\"type\":\"MagentoSource\",\"query\":\"dataqgpldrn\",\"queryTimeout\":\"datahdb\",\"additionalColumns\":\"databmsbetzufkvx\",\"sourceRetryCount\":\"databddrtngdc\",\"sourceRetryWait\":\"datajzgzaeuu\",\"maxConcurrentConnections\":\"datavheqzl\",\"disableMetricsCollection\":\"datavaskrgoodfhpyue\",\"\":{\"lizlzxh\":\"datanyddp\",\"sjwawl\":\"datacuglgmfznholaf\",\"yk\":\"dataqmznkcwiok\"}}")
+ "{\"type\":\"MagentoSource\",\"query\":\"datajjprd\",\"queryTimeout\":\"datablonlhtgexwjhicu\",\"additionalColumns\":\"dataavimxnhylwogtvl\",\"sourceRetryCount\":\"datagd\",\"sourceRetryWait\":\"datat\",\"maxConcurrentConnections\":\"datadxlfn\",\"disableMetricsCollection\":\"dataclkmggnzlfyxaiaf\",\"\":{\"uoayapzzcxkuusba\":\"dataxekfvycvhw\",\"yak\":\"datacassqeybdnz\",\"zkicxtumqinawct\":\"datarkohfqm\",\"kjnpe\":\"dataarboxaluoadmcv\"}}")
.toObject(MagentoSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MagentoSource model = new MagentoSource().withSourceRetryCount("databddrtngdc")
- .withSourceRetryWait("datajzgzaeuu")
- .withMaxConcurrentConnections("datavheqzl")
- .withDisableMetricsCollection("datavaskrgoodfhpyue")
- .withQueryTimeout("datahdb")
- .withAdditionalColumns("databmsbetzufkvx")
- .withQuery("dataqgpldrn");
+ MagentoSource model = new MagentoSource().withSourceRetryCount("datagd")
+ .withSourceRetryWait("datat")
+ .withMaxConcurrentConnections("datadxlfn")
+ .withDisableMetricsCollection("dataclkmggnzlfyxaiaf")
+ .withQueryTimeout("datablonlhtgexwjhicu")
+ .withAdditionalColumns("dataavimxnhylwogtvl")
+ .withQuery("datajjprd");
model = BinaryData.fromObject(model).toObject(MagentoSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityCredentialTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityCredentialTests.java
index adcc6b4faa6c..466de24d9e17 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityCredentialTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityCredentialTests.java
@@ -13,19 +13,20 @@ public final class ManagedIdentityCredentialTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ManagedIdentityCredential model = BinaryData.fromString(
- "{\"type\":\"ManagedIdentity\",\"typeProperties\":{\"resourceId\":\"aaznuwuwbnngcd\"},\"description\":\"xy\",\"annotations\":[\"datab\",\"datadiqpadhrijxu\",\"datatjcyllpasx\",\"dataqsfpctq\"],\"\":{\"squ\":\"databjjde\"}}")
+ "{\"type\":\"ManagedIdentity\",\"typeProperties\":{\"resourceId\":\"teiulvrpvhi\"},\"description\":\"lmzcvpoyhvfcwe\",\"annotations\":[\"dataeroezgibfisfmcx\",\"datarhgcuejtxxlkokt\",\"dataclpvwtwboxgrv\",\"dataavoqbsquwkuszll\"],\"\":{\"nyg\":\"dataledhvll\",\"vqaq\":\"datamn\",\"ulwdhjb\":\"datazo\"}}")
.toObject(ManagedIdentityCredential.class);
- Assertions.assertEquals("xy", model.description());
- Assertions.assertEquals("aaznuwuwbnngcd", model.resourceId());
+ Assertions.assertEquals("lmzcvpoyhvfcwe", model.description());
+ Assertions.assertEquals("teiulvrpvhi", model.resourceId());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ManagedIdentityCredential model = new ManagedIdentityCredential().withDescription("xy")
- .withAnnotations(Arrays.asList("datab", "datadiqpadhrijxu", "datatjcyllpasx", "dataqsfpctq"))
- .withResourceId("aaznuwuwbnngcd");
+ ManagedIdentityCredential model = new ManagedIdentityCredential().withDescription("lmzcvpoyhvfcwe")
+ .withAnnotations(
+ Arrays.asList("dataeroezgibfisfmcx", "datarhgcuejtxxlkokt", "dataclpvwtwboxgrv", "dataavoqbsquwkuszll"))
+ .withResourceId("teiulvrpvhi");
model = BinaryData.fromObject(model).toObject(ManagedIdentityCredential.class);
- Assertions.assertEquals("xy", model.description());
- Assertions.assertEquals("aaznuwuwbnngcd", model.resourceId());
+ Assertions.assertEquals("lmzcvpoyhvfcwe", model.description());
+ Assertions.assertEquals("teiulvrpvhi", model.resourceId());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityTypePropertiesTests.java
index 0cb78776db58..6dc3a53aa137 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedIdentityTypePropertiesTests.java
@@ -11,15 +11,15 @@
public final class ManagedIdentityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- ManagedIdentityTypeProperties model = BinaryData.fromString("{\"resourceId\":\"rnbdzvcabchdzxj\"}")
- .toObject(ManagedIdentityTypeProperties.class);
- Assertions.assertEquals("rnbdzvcabchdzxj", model.resourceId());
+ ManagedIdentityTypeProperties model
+ = BinaryData.fromString("{\"resourceId\":\"flbch\"}").toObject(ManagedIdentityTypeProperties.class);
+ Assertions.assertEquals("flbch", model.resourceId());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ManagedIdentityTypeProperties model = new ManagedIdentityTypeProperties().withResourceId("rnbdzvcabchdzxj");
+ ManagedIdentityTypeProperties model = new ManagedIdentityTypeProperties().withResourceId("flbch");
model = BinaryData.fromObject(model).toObject(ManagedIdentityTypeProperties.class);
- Assertions.assertEquals("rnbdzvcabchdzxj", model.resourceId());
+ Assertions.assertEquals("flbch", model.resourceId());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsCreateOrUpdateWithResponseMockTests.java
index 15a6c8050fac..05b3250dff6a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsCreateOrUpdateWithResponseMockTests.java
@@ -26,7 +26,7 @@ public final class ManagedPrivateEndpointsCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"connectionState\":{\"actionsRequired\":\"jyfiabhepxqtkynl\",\"description\":\"norhwdo\",\"status\":\"ythsl\"},\"fqdns\":[\"lvwbgbmpit\"],\"groupId\":\"xhiuhgvgnolusqfd\",\"isReserved\":true,\"privateLinkResourceId\":\"pwvieymkguvrd\",\"provisioningState\":\"proytd\",\"\":{\"vmvpp\":\"datalq\",\"is\":\"datatsolxnhlrpsign\"}},\"name\":\"obpxfgp\",\"type\":\"zdzswvfwiunjwqx\",\"etag\":\"tfzgdq\",\"id\":\"vbiryxsa\"}";
+ = "{\"properties\":{\"connectionState\":{\"actionsRequired\":\"fiwaocf\",\"description\":\"fjxdccwuzqwv\",\"status\":\"ewl\"},\"fqdns\":[\"eupsubawza\",\"zdzhhgbxcel\",\"awwjobtkyjvzzb\",\"ylimnm\"],\"groupId\":\"sjuacdqvr\",\"isReserved\":true,\"privateLinkResourceId\":\"qotzpepmlckz\",\"provisioningState\":\"ietfx\",\"\":{\"ehvmrao\":\"datazlivkaxwfkanuqf\",\"jti\":\"dataniibcily\",\"igy\":\"datahzjhqfuqomwh\",\"jjhn\":\"datagqewcv\"}},\"name\":\"rsgrt\",\"type\":\"depaun\",\"etag\":\"knucsrqfmcrye\",\"id\":\"lx\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -36,20 +36,20 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ManagedPrivateEndpointResource response = manager.managedPrivateEndpoints()
- .define("zbg")
- .withExistingManagedVirtualNetwork("cwacchixdafrx", "rhqzjz", "onttfvjfwl")
+ .define("ukc")
+ .withExistingManagedVirtualNetwork("krejuuii", "rbtfarb", "arxyh")
.withProperties(new ManagedPrivateEndpoint().withConnectionState(new ConnectionStateProperties())
- .withFqdns(Arrays.asList("sayiivoixefncqf", "wqnz", "ctnmkitsvkuop", "vqsabopou"))
- .withGroupId("gxnzpqegga")
- .withPrivateLinkResourceId("zudysndiexb")
- .withAdditionalProperties(mapOf("isReserved", false, "provisioningState", "wjmqn")))
- .withIfMatch("nfwijlvkrnsodohp")
+ .withFqdns(Arrays.asList("czlyludrziaxige", "smuhkhnzsr"))
+ .withGroupId("wvzepgljtu")
+ .withPrivateLinkResourceId("prnfrl")
+ .withAdditionalProperties(mapOf("isReserved", false, "provisioningState", "cnbrwhsqtzgmf")))
+ .withIfMatch("itoibgv")
.create();
- Assertions.assertEquals("vbiryxsa", response.id());
- Assertions.assertEquals("lvwbgbmpit", response.properties().fqdns().get(0));
- Assertions.assertEquals("xhiuhgvgnolusqfd", response.properties().groupId());
- Assertions.assertEquals("pwvieymkguvrd", response.properties().privateLinkResourceId());
+ Assertions.assertEquals("lx", response.id());
+ Assertions.assertEquals("eupsubawza", response.properties().fqdns().get(0));
+ Assertions.assertEquals("sjuacdqvr", response.properties().groupId());
+ Assertions.assertEquals("qotzpepmlckz", response.properties().privateLinkResourceId());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsDeleteWithResponseMockTests.java
index ce1c201595ae..46a3edec250f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsDeleteWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.managedPrivateEndpoints()
- .deleteWithResponse("ebberydeoeyef", "nibhqieytup", "xahzjntoqfxoapw", "lvyxomugzbrygw",
+ .deleteWithResponse("ba", "ycnjxyproqebsuij", "mwbshqpjueo", "htltooikzouv",
com.azure.core.util.Context.NONE);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsGetWithResponseMockTests.java
index 19839aa19eed..6b30aa8ff090 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class ManagedPrivateEndpointsGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"connectionState\":{\"actionsRequired\":\"ofvzpbd\",\"description\":\"qtruyzbrkzsax\",\"status\":\"nsepdwxflmk\"},\"fqdns\":[\"idripnut\"],\"groupId\":\"hzejkuszq\",\"isReserved\":false,\"privateLinkResourceId\":\"tgzrgmc\",\"provisioningState\":\"vvjamxgqxb\",\"\":{\"ju\":\"dataxe\",\"uvxvdu\":\"dataykommmygmit\"}},\"name\":\"bd\",\"type\":\"vx\",\"etag\":\"o\",\"id\":\"xu\"}";
+ = "{\"properties\":{\"connectionState\":{\"actionsRequired\":\"flmalmx\",\"description\":\"rdpfanjkenrlcjms\",\"status\":\"gmebxwdahh\"},\"fqdns\":[\"uogakrpmjodbdcy\",\"jnoibclfqdtfj\"],\"groupId\":\"v\",\"isReserved\":true,\"privateLinkResourceId\":\"yvstv\",\"provisioningState\":\"slqyhabgocq\",\"\":{\"lwgr\":\"dataivofnhckl\"}},\"name\":\"lqqkpxvemj\",\"type\":\"vanefwsodnl\",\"etag\":\"npbgqemjdtc\",\"id\":\"kwkxlnl\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,12 +31,12 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ManagedPrivateEndpointResource response = manager.managedPrivateEndpoints()
- .getWithResponse("mlcenty", "d", "kvmft", "qaewu", "poltq", com.azure.core.util.Context.NONE)
+ .getWithResponse("xhfusjxnadiese", "zfh", "ihrxg", "ub", "xajrnqoujvzpv", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("xu", response.id());
- Assertions.assertEquals("idripnut", response.properties().fqdns().get(0));
- Assertions.assertEquals("hzejkuszq", response.properties().groupId());
- Assertions.assertEquals("tgzrgmc", response.properties().privateLinkResourceId());
+ Assertions.assertEquals("kwkxlnl", response.id());
+ Assertions.assertEquals("uogakrpmjodbdcy", response.properties().fqdns().get(0));
+ Assertions.assertEquals("v", response.properties().groupId());
+ Assertions.assertEquals("yvstv", response.properties().privateLinkResourceId());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsListByFactoryMockTests.java
index 4afd0e63ae02..70f056f3cf79 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedPrivateEndpointsListByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class ManagedPrivateEndpointsListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"connectionState\":{\"actionsRequired\":\"zpupkebwsesblsb\",\"description\":\"dfoprdytsgypvi\",\"status\":\"ooqzdoytnpkjp\"},\"fqdns\":[\"gnhzufhw\",\"tjnvrptqxksid\",\"jfh\"],\"groupId\":\"gizzrlx\",\"isReserved\":true,\"privateLinkResourceId\":\"xjqqozxtnowv\",\"provisioningState\":\"fypdxsy\",\"\":{\"mwvdmwaamqfeq\":\"datauueeokvq\",\"tqaomihrtbksd\":\"databjygnckeq\"}},\"name\":\"pxwficzzoxnl\",\"type\":\"xndsiqxzaolzko\",\"etag\":\"iragbbiukmkmthio\",\"id\":\"oh\"}]}";
+ = "{\"value\":[{\"properties\":{\"connectionState\":{\"actionsRequired\":\"md\",\"description\":\"rgmjpckefw\",\"status\":\"u\"},\"fqdns\":[\"lby\"],\"groupId\":\"pr\",\"isReserved\":false,\"privateLinkResourceId\":\"iivbv\",\"provisioningState\":\"omnosl\",\"\":{\"zjudgwdsflit\":\"datahrnv\"}},\"name\":\"xvuzofueb\",\"type\":\"rsf\",\"etag\":\"ajuzh\",\"id\":\"pxvkpbaftf\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,11 +32,11 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response = manager.managedPrivateEndpoints()
- .listByFactory("twt", "kkhuusr", "utonp", com.azure.core.util.Context.NONE);
+ .listByFactory("wv", "p", "yexamsgfvuffdvuk", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("oh", response.iterator().next().id());
- Assertions.assertEquals("gnhzufhw", response.iterator().next().properties().fqdns().get(0));
- Assertions.assertEquals("gizzrlx", response.iterator().next().properties().groupId());
- Assertions.assertEquals("xjqqozxtnowv", response.iterator().next().properties().privateLinkResourceId());
+ Assertions.assertEquals("pxvkpbaftf", response.iterator().next().id());
+ Assertions.assertEquals("lby", response.iterator().next().properties().fqdns().get(0));
+ Assertions.assertEquals("pr", response.iterator().next().properties().groupId());
+ Assertions.assertEquals("iivbv", response.iterator().next().properties().privateLinkResourceId());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksCreateOrUpdateWithResponseMockTests.java
index 1bb874324649..8c838ae408ca 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksCreateOrUpdateWithResponseMockTests.java
@@ -24,7 +24,7 @@ public final class ManagedVirtualNetworksCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"vNetId\":\"pbln\",\"alias\":\"ugecijrncv\",\"\":{\"bcjvvdafbt\":\"datauwurcxtyfbbomug\"}},\"name\":\"xvkoiebplyyxml\",\"type\":\"seaogqiybfskxu\",\"etag\":\"sddrye\",\"id\":\"lqqcwpgipttpse\"}";
+ = "{\"properties\":{\"vNetId\":\"q\",\"alias\":\"psxycvoexbx\",\"\":{\"acgmnelozzfwyegd\":\"datavxwlfmbb\",\"esdfujfpn\":\"datatfktmdlfkjjucptr\",\"msybvjfnuyoy\":\"datafzabl\"}},\"name\":\"a\",\"type\":\"nnlasf\",\"etag\":\"jyvu\",\"id\":\"exlpmbtmc\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -34,14 +34,14 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ManagedVirtualNetworkResource response = manager.managedVirtualNetworks()
- .define("ipwkxf")
- .withExistingFactory("gxohiwkkht", "eukclay")
+ .define("r")
+ .withExistingFactory("fb", "sdoaypi")
.withProperties(new ManagedVirtualNetwork()
- .withAdditionalProperties(mapOf("vNetId", "harsvai", "alias", "medioakprlajt")))
- .withIfMatch("mxlnt")
+ .withAdditionalProperties(mapOf("vNetId", "hlbzxyejoxdbrjul", "alias", "qgunptbpicc")))
+ .withIfMatch("ekb")
.create();
- Assertions.assertEquals("lqqcwpgipttpse", response.id());
+ Assertions.assertEquals("exlpmbtmc", response.id());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksGetWithResponseMockTests.java
index 651759b4a603..5292ee566667 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class ManagedVirtualNetworksGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"vNetId\":\"bheiywmxsxl\",\"alias\":\"lqtnngw\",\"\":{\"bgaafttv\":\"datafrt\",\"afrwmxmd\":\"datamdnigajbxjnrlfdq\"}},\"name\":\"zhutcaqqdchmxr\",\"type\":\"ljqhoiqvk\",\"etag\":\"djlxzt\",\"id\":\"vawy\"}";
+ = "{\"properties\":{\"vNetId\":\"xausivh\",\"alias\":\"unnjwmdtbx\",\"\":{\"elxd\":\"datamcbaiamtdfpkfwzq\"}},\"name\":\"dfsteouzoglvt\",\"type\":\"jlejvlf\",\"etag\":\"rqkgibpehqb\",\"id\":\"zcmqqehxigsi\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,9 +31,9 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
ManagedVirtualNetworkResource response = manager.managedVirtualNetworks()
- .getWithResponse("rxaww", "kgzsqrirlcjm", "aarkhlayercs", "iuwne", com.azure.core.util.Context.NONE)
+ .getWithResponse("iyavfeyyb", "duyastybomiyj", "jsseemhdf", "lai", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("vawy", response.id());
+ Assertions.assertEquals("zcmqqehxigsi", response.id());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksListByFactoryMockTests.java
index 1c150c70aa3d..ba85401a004a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ManagedVirtualNetworksListByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class ManagedVirtualNetworksListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"vNetId\":\"jpkojykyt\",\"alias\":\"irctdaojhukwykik\",\"\":{\"obhaomaowpm\":\"datamlhszipihenvhlp\",\"ogboaimwxswfytn\":\"datajsvuz\",\"gtgc\":\"datacjhjrwn\"}},\"name\":\"p\",\"type\":\"rhxfgswyafdlfky\",\"etag\":\"j\",\"id\":\"wrqivibzoqgu\"}]}";
+ = "{\"value\":[{\"properties\":{\"vNetId\":\"svowvqpnci\",\"alias\":\"xtib\",\"\":{\"cswhm\":\"datahzpfdlcst\",\"hmatfgoerjmhtxip\":\"datasdw\",\"vrrzmkteuzeuxx\":\"datavwzbkgt\"}},\"name\":\"l\",\"type\":\"cwl\",\"etag\":\"xxpwexcktgpcccg\",\"id\":\"knjjskzuh\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,8 +32,8 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response = manager.managedVirtualNetworks()
- .listByFactory("rovrfdf", "dvifoxozqcy", com.azure.core.util.Context.NONE);
+ .listByFactory("ptvymbmpdcddb", "ozhprlxxbmyzfayj", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("wrqivibzoqgu", response.iterator().next().id());
+ Assertions.assertEquals("knjjskzuh", response.iterator().next().id());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBSourceTests.java
index 9b582bf435d1..7a8470019250 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBSourceTests.java
@@ -11,19 +11,19 @@ public final class MariaDBSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MariaDBSource model = BinaryData.fromString(
- "{\"type\":\"MariaDBSource\",\"query\":\"dataxmobnehbbchtcoel\",\"queryTimeout\":\"datafnpxumgnjmsk\",\"additionalColumns\":\"dataeuogjiowande\",\"sourceRetryCount\":\"dataebpalz\",\"sourceRetryWait\":\"dataptg\",\"maxConcurrentConnections\":\"datarz\",\"disableMetricsCollection\":\"datacfdsvmptnrz\",\"\":{\"ovqpnxpufvggv\":\"datacncdazwtlgora\"}}")
+ "{\"type\":\"MariaDBSource\",\"query\":\"datawevlohuahl\",\"queryTimeout\":\"datacboxgpmmz\",\"additionalColumns\":\"dataoyllxc\",\"sourceRetryCount\":\"datahzylspz\",\"sourceRetryWait\":\"datarhynlbtr\",\"maxConcurrentConnections\":\"dataecvag\",\"disableMetricsCollection\":\"datarhadg\",\"\":{\"hiafbhzdjv\":\"datarasxeomjqqhbkxi\",\"ggbpdpzgvq\":\"datayrzi\",\"lvxilaytj\":\"dataznxzaliicrutyhm\",\"ghqdlj\":\"datawfqzwn\"}}")
.toObject(MariaDBSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MariaDBSource model = new MariaDBSource().withSourceRetryCount("dataebpalz")
- .withSourceRetryWait("dataptg")
- .withMaxConcurrentConnections("datarz")
- .withDisableMetricsCollection("datacfdsvmptnrz")
- .withQueryTimeout("datafnpxumgnjmsk")
- .withAdditionalColumns("dataeuogjiowande")
- .withQuery("dataxmobnehbbchtcoel");
+ MariaDBSource model = new MariaDBSource().withSourceRetryCount("datahzylspz")
+ .withSourceRetryWait("datarhynlbtr")
+ .withMaxConcurrentConnections("dataecvag")
+ .withDisableMetricsCollection("datarhadg")
+ .withQueryTimeout("datacboxgpmmz")
+ .withAdditionalColumns("dataoyllxc")
+ .withQuery("datawevlohuahl");
model = BinaryData.fromObject(model).toObject(MariaDBSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBTableDatasetTests.java
index aab03211b3a0..6e44e2bdb1a1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MariaDBTableDatasetTests.java
@@ -19,34 +19,31 @@ public final class MariaDBTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MariaDBTableDataset model = BinaryData.fromString(
- "{\"type\":\"MariaDBTable\",\"typeProperties\":{\"tableName\":\"datarmrfyyqjcni\"},\"description\":\"qrsdd\",\"structure\":\"dataqddldao\",\"schema\":\"datafztqewq\",\"linkedServiceName\":{\"referenceName\":\"ojesxjhtyzzwqocy\",\"parameters\":{\"trgu\":\"dataineuaxpmez\",\"oyxfoafzdypzlx\":\"datalw\",\"jzqx\":\"datamndhgwhlbpju\",\"lyhbujys\":\"datavmitn\"}},\"parameters\":{\"gnqtjtnnrjewih\":{\"type\":\"Bool\",\"defaultValue\":\"dataddbhatmabt\"},\"hmdfspkdn\":{\"type\":\"String\",\"defaultValue\":\"dataa\"},\"tertnzrrwsc\":{\"type\":\"Int\",\"defaultValue\":\"dataz\"}},\"annotations\":[\"datahdwi\",\"datanvtolzj\"],\"folder\":{\"name\":\"ryxsg\"},\"\":{\"wppvihbmwrv\":\"datanklth\",\"ob\":\"datavdrohu\"}}")
+ "{\"type\":\"MariaDBTable\",\"typeProperties\":{\"tableName\":\"datatmabtpgn\"},\"description\":\"jtn\",\"structure\":\"datajewihcigaahm\",\"schema\":\"dataspkdnx\",\"linkedServiceName\":{\"referenceName\":\"xzxtertn\",\"parameters\":{\"olzjyf\":\"datawsciclhdwienv\",\"aknk\":\"dataryxsg\"}},\"parameters\":{\"vihbmwrv\":{\"type\":\"SecureString\",\"defaultValue\":\"datap\"}},\"annotations\":[\"datarohulobkabhvxjua\",\"datavxznirnygtixkg\"],\"folder\":{\"name\":\"mkphvdl\"},\"\":{\"cltfcieileem\":\"datazpqditu\",\"sgikkmibnmdpid\":\"datatkehldopjsxvbb\",\"styzavkyjjlu\":\"datapwtgzwmzhcmrloqa\",\"bngzldvvd\":\"datanmbj\"}}")
.toObject(MariaDBTableDataset.class);
- Assertions.assertEquals("qrsdd", model.description());
- Assertions.assertEquals("ojesxjhtyzzwqocy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("gnqtjtnnrjewih").type());
- Assertions.assertEquals("ryxsg", model.folder().name());
+ Assertions.assertEquals("jtn", model.description());
+ Assertions.assertEquals("xzxtertn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("vihbmwrv").type());
+ Assertions.assertEquals("mkphvdl", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MariaDBTableDataset model = new MariaDBTableDataset().withDescription("qrsdd")
- .withStructure("dataqddldao")
- .withSchema("datafztqewq")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ojesxjhtyzzwqocy")
- .withParameters(mapOf("trgu", "dataineuaxpmez", "oyxfoafzdypzlx", "datalw", "jzqx", "datamndhgwhlbpju",
- "lyhbujys", "datavmitn")))
- .withParameters(mapOf("gnqtjtnnrjewih",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataddbhatmabt"),
- "hmdfspkdn", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataa"),
- "tertnzrrwsc", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataz")))
- .withAnnotations(Arrays.asList("datahdwi", "datanvtolzj"))
- .withFolder(new DatasetFolder().withName("ryxsg"))
- .withTableName("datarmrfyyqjcni");
+ MariaDBTableDataset model = new MariaDBTableDataset().withDescription("jtn")
+ .withStructure("datajewihcigaahm")
+ .withSchema("dataspkdnx")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xzxtertn")
+ .withParameters(mapOf("olzjyf", "datawsciclhdwienv", "aknk", "dataryxsg")))
+ .withParameters(mapOf("vihbmwrv",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datap")))
+ .withAnnotations(Arrays.asList("datarohulobkabhvxjua", "datavxznirnygtixkg"))
+ .withFolder(new DatasetFolder().withName("mkphvdl"))
+ .withTableName("datatmabtpgn");
model = BinaryData.fromObject(model).toObject(MariaDBTableDataset.class);
- Assertions.assertEquals("qrsdd", model.description());
- Assertions.assertEquals("ojesxjhtyzzwqocy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("gnqtjtnnrjewih").type());
- Assertions.assertEquals("ryxsg", model.folder().name());
+ Assertions.assertEquals("jtn", model.description());
+ Assertions.assertEquals("xzxtertn", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("vihbmwrv").type());
+ Assertions.assertEquals("mkphvdl", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoObjectDatasetTests.java
index d406ab2b777c..82fdbd56b3e4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoObjectDatasetTests.java
@@ -19,31 +19,32 @@ public final class MarketoObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MarketoObjectDataset model = BinaryData.fromString(
- "{\"type\":\"MarketoObject\",\"typeProperties\":{\"tableName\":\"dataewltono\"},\"description\":\"femiwfhhawbabhz\",\"structure\":\"datacdikqnxydgzfoiqz\",\"schema\":\"dataspa\",\"linkedServiceName\":{\"referenceName\":\"w\",\"parameters\":{\"eafkxfmuwdbvyt\":\"dataqeron\",\"u\":\"dataavouymkd\"}},\"parameters\":{\"tth\":{\"type\":\"Float\",\"defaultValue\":\"datapfdkaxgbiwpgopql\"}},\"annotations\":[\"datarmt\",\"datax\",\"datajmpdvrjzwaw\",\"dataewajccsdjuz\"],\"folder\":{\"name\":\"jtickzovguzpr\"},\"\":{\"qlrzhtocjzfp\":\"datahboigzxko\",\"jwgiitvjcmimbmsw\":\"dataexuvatzwn\"}}")
+ "{\"type\":\"MarketoObject\",\"typeProperties\":{\"tableName\":\"dataickzovguzprpxhhb\"},\"description\":\"gzxkopqlrzhtocjz\",\"structure\":\"datapexuvat\",\"schema\":\"datankjwgiitvjcmimb\",\"linkedServiceName\":{\"referenceName\":\"swskbbbj\",\"parameters\":{\"sobggva\":\"dataplodaqrbkpozf\",\"p\":\"datacrqaxlmbrtvtgolm\",\"yxhxj\":\"datagtla\"}},\"parameters\":{\"fhfaobqnjcsb\":{\"type\":\"Float\",\"defaultValue\":\"dataaqqjh\"}},\"annotations\":[\"datacdqwssydvwryb\",\"datavywotjnjuvtzij\"],\"folder\":{\"name\":\"xbaeyocpkvlt\"},\"\":{\"oztnhvd\":\"datazfmnpbdrcibjxnn\"}}")
.toObject(MarketoObjectDataset.class);
- Assertions.assertEquals("femiwfhhawbabhz", model.description());
- Assertions.assertEquals("w", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("tth").type());
- Assertions.assertEquals("jtickzovguzpr", model.folder().name());
+ Assertions.assertEquals("gzxkopqlrzhtocjz", model.description());
+ Assertions.assertEquals("swskbbbj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("fhfaobqnjcsb").type());
+ Assertions.assertEquals("xbaeyocpkvlt", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MarketoObjectDataset model = new MarketoObjectDataset().withDescription("femiwfhhawbabhz")
- .withStructure("datacdikqnxydgzfoiqz")
- .withSchema("dataspa")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("w")
- .withParameters(mapOf("eafkxfmuwdbvyt", "dataqeron", "u", "dataavouymkd")))
- .withParameters(mapOf("tth",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datapfdkaxgbiwpgopql")))
- .withAnnotations(Arrays.asList("datarmt", "datax", "datajmpdvrjzwaw", "dataewajccsdjuz"))
- .withFolder(new DatasetFolder().withName("jtickzovguzpr"))
- .withTableName("dataewltono");
+ MarketoObjectDataset model = new MarketoObjectDataset().withDescription("gzxkopqlrzhtocjz")
+ .withStructure("datapexuvat")
+ .withSchema("datankjwgiitvjcmimb")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("swskbbbj")
+ .withParameters(
+ mapOf("sobggva", "dataplodaqrbkpozf", "p", "datacrqaxlmbrtvtgolm", "yxhxj", "datagtla")))
+ .withParameters(mapOf("fhfaobqnjcsb",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataaqqjh")))
+ .withAnnotations(Arrays.asList("datacdqwssydvwryb", "datavywotjnjuvtzij"))
+ .withFolder(new DatasetFolder().withName("xbaeyocpkvlt"))
+ .withTableName("dataickzovguzprpxhhb");
model = BinaryData.fromObject(model).toObject(MarketoObjectDataset.class);
- Assertions.assertEquals("femiwfhhawbabhz", model.description());
- Assertions.assertEquals("w", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("tth").type());
- Assertions.assertEquals("jtickzovguzpr", model.folder().name());
+ Assertions.assertEquals("gzxkopqlrzhtocjz", model.description());
+ Assertions.assertEquals("swskbbbj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("fhfaobqnjcsb").type());
+ Assertions.assertEquals("xbaeyocpkvlt", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoSourceTests.java
index 6d53c4fb9021..2c823ed4e20c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MarketoSourceTests.java
@@ -11,19 +11,19 @@ public final class MarketoSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MarketoSource model = BinaryData.fromString(
- "{\"type\":\"MarketoSource\",\"query\":\"dataht\",\"queryTimeout\":\"datauiptudw\",\"additionalColumns\":\"datasrpsjkqfabju\",\"sourceRetryCount\":\"datats\",\"sourceRetryWait\":\"dataupcio\",\"maxConcurrentConnections\":\"datarjdeyfnqanbadkzp\",\"disableMetricsCollection\":\"datatuplpkjexq\",\"\":{\"goeftrbxomaa\":\"datazlal\",\"gvjmllzykalbaumm\":\"datavarfqverxelquqze\",\"r\":\"datadwqiucpj\",\"ftt\":\"databssjtjwzelx\"}}")
+ "{\"type\":\"MarketoSource\",\"query\":\"datagw\",\"queryTimeout\":\"dataujshcsnk\",\"additionalColumns\":\"datagpqxqevt\",\"sourceRetryCount\":\"datavyy\",\"sourceRetryWait\":\"datakjirvjogsalvjl\",\"maxConcurrentConnections\":\"dataimua\",\"disableMetricsCollection\":\"datakympwquu\",\"\":{\"iqeftgunropdpuf\":\"dataofuzthszjyanhs\"}}")
.toObject(MarketoSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MarketoSource model = new MarketoSource().withSourceRetryCount("datats")
- .withSourceRetryWait("dataupcio")
- .withMaxConcurrentConnections("datarjdeyfnqanbadkzp")
- .withDisableMetricsCollection("datatuplpkjexq")
- .withQueryTimeout("datauiptudw")
- .withAdditionalColumns("datasrpsjkqfabju")
- .withQuery("dataht");
+ MarketoSource model = new MarketoSource().withSourceRetryCount("datavyy")
+ .withSourceRetryWait("datakjirvjogsalvjl")
+ .withMaxConcurrentConnections("dataimua")
+ .withDisableMetricsCollection("datakympwquu")
+ .withQueryTimeout("dataujshcsnk")
+ .withAdditionalColumns("datagpqxqevt")
+ .withQuery("datagw");
model = BinaryData.fromObject(model).toObject(MarketoSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MetadataItemTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MetadataItemTests.java
index 43ea3f27efbd..46be8b4d66c6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MetadataItemTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MetadataItemTests.java
@@ -10,14 +10,13 @@
public final class MetadataItemTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- MetadataItem model
- = BinaryData.fromString("{\"name\":\"datamgsejisydhardxnk\",\"value\":\"dataqfffglftlqakie\"}")
- .toObject(MetadataItem.class);
+ MetadataItem model = BinaryData.fromString("{\"name\":\"datatohruqtximrxeyz\",\"value\":\"datanxb\"}")
+ .toObject(MetadataItem.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MetadataItem model = new MetadataItem().withName("datamgsejisydhardxnk").withValue("dataqfffglftlqakie");
+ MetadataItem model = new MetadataItem().withName("datatohruqtximrxeyz").withValue("datanxb");
model = BinaryData.fromObject(model).toObject(MetadataItem.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSinkTests.java
index e414b6f5506c..92def7b321fb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSinkTests.java
@@ -11,19 +11,19 @@ public final class MicrosoftAccessSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MicrosoftAccessSink model = BinaryData.fromString(
- "{\"type\":\"MicrosoftAccessSink\",\"preCopyScript\":\"datawimmmmgbynvoytd\",\"writeBatchSize\":\"datakfqznvahpxdg\",\"writeBatchTimeout\":\"dataowxcptxvxfwwv\",\"sinkRetryCount\":\"datagcfazt\",\"sinkRetryWait\":\"dataaszjrihca\",\"maxConcurrentConnections\":\"dataj\",\"disableMetricsCollection\":\"datavkttiteb\",\"\":{\"zlzzmygoutqe\":\"datapmoadjooer\",\"wp\":\"datapuoyc\",\"ufdxpwj\":\"dataxqx\",\"cecukzt\":\"dataajvskpbu\"}}")
+ "{\"type\":\"MicrosoftAccessSink\",\"preCopyScript\":\"datanpry\",\"writeBatchSize\":\"dataujqyeyzoivi\",\"writeBatchTimeout\":\"datanihmwvhc\",\"sinkRetryCount\":\"datamua\",\"sinkRetryWait\":\"datatd\",\"maxConcurrentConnections\":\"datai\",\"disableMetricsCollection\":\"datazytdj\",\"\":{\"bxm\":\"datansdadyrhmpokfxc\"}}")
.toObject(MicrosoftAccessSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MicrosoftAccessSink model = new MicrosoftAccessSink().withWriteBatchSize("datakfqznvahpxdg")
- .withWriteBatchTimeout("dataowxcptxvxfwwv")
- .withSinkRetryCount("datagcfazt")
- .withSinkRetryWait("dataaszjrihca")
- .withMaxConcurrentConnections("dataj")
- .withDisableMetricsCollection("datavkttiteb")
- .withPreCopyScript("datawimmmmgbynvoytd");
+ MicrosoftAccessSink model = new MicrosoftAccessSink().withWriteBatchSize("dataujqyeyzoivi")
+ .withWriteBatchTimeout("datanihmwvhc")
+ .withSinkRetryCount("datamua")
+ .withSinkRetryWait("datatd")
+ .withMaxConcurrentConnections("datai")
+ .withDisableMetricsCollection("datazytdj")
+ .withPreCopyScript("datanpry");
model = BinaryData.fromObject(model).toObject(MicrosoftAccessSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSourceTests.java
index 574127e0d05c..e05f4de3fd34 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessSourceTests.java
@@ -11,18 +11,18 @@ public final class MicrosoftAccessSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MicrosoftAccessSource model = BinaryData.fromString(
- "{\"type\":\"MicrosoftAccessSource\",\"query\":\"databgljcy\",\"additionalColumns\":\"datarzxipxhlxxkviyj\",\"sourceRetryCount\":\"dataqyejyavxgm\",\"sourceRetryWait\":\"datacnwxkqqxpnj\",\"maxConcurrentConnections\":\"datazdahvethn\",\"disableMetricsCollection\":\"dataeggyqlvnhmuut\",\"\":{\"k\":\"datatymbccmwsyfsg\"}}")
+ "{\"type\":\"MicrosoftAccessSource\",\"query\":\"datacyhfubzixqxxgra\",\"additionalColumns\":\"dataftzn\",\"sourceRetryCount\":\"datarfhj\",\"sourceRetryWait\":\"dataiutbrnr\",\"maxConcurrentConnections\":\"dataljucodrbkdieismd\",\"disableMetricsCollection\":\"datafim\",\"\":{\"foexlcskelwzmji\":\"dataijrlmnkvp\"}}")
.toObject(MicrosoftAccessSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MicrosoftAccessSource model = new MicrosoftAccessSource().withSourceRetryCount("dataqyejyavxgm")
- .withSourceRetryWait("datacnwxkqqxpnj")
- .withMaxConcurrentConnections("datazdahvethn")
- .withDisableMetricsCollection("dataeggyqlvnhmuut")
- .withQuery("databgljcy")
- .withAdditionalColumns("datarzxipxhlxxkviyj");
+ MicrosoftAccessSource model = new MicrosoftAccessSource().withSourceRetryCount("datarfhj")
+ .withSourceRetryWait("dataiutbrnr")
+ .withMaxConcurrentConnections("dataljucodrbkdieismd")
+ .withDisableMetricsCollection("datafim")
+ .withQuery("datacyhfubzixqxxgra")
+ .withAdditionalColumns("dataftzn");
model = BinaryData.fromObject(model).toObject(MicrosoftAccessSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTests.java
index a5153b94bc67..60acbfebc3ba 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTests.java
@@ -19,36 +19,32 @@ public final class MicrosoftAccessTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MicrosoftAccessTableDataset model = BinaryData.fromString(
- "{\"type\":\"MicrosoftAccessTable\",\"typeProperties\":{\"tableName\":\"datanrkbnv\"},\"description\":\"cklzhznfgvlxy\",\"structure\":\"datanctigpksywi\",\"schema\":\"datalktgkdp\",\"linkedServiceName\":{\"referenceName\":\"tqjytdc\",\"parameters\":{\"gmlamoaxc\":\"datauhbdwbvjs\",\"kvbpbl\":\"dataytn\",\"exheeocnqo\":\"datacw\"}},\"parameters\":{\"xyfhxohzbzhhavzf\":{\"type\":\"Object\",\"defaultValue\":\"datavlryszfh\"},\"cofuvtfu\":{\"type\":\"Array\",\"defaultValue\":\"datavkds\"},\"subzsspmj\":{\"type\":\"Bool\",\"defaultValue\":\"datauisaklhjfddxqfu\"},\"wbztrt\":{\"type\":\"Int\",\"defaultValue\":\"datalfauyvxpqwlkqd\"}},\"annotations\":[\"datawvoglff\",\"datadhg\"],\"folder\":{\"name\":\"rmhbtofcv\"},\"\":{\"g\":\"datalhcnsdylmnqunk\"}}")
+ "{\"type\":\"MicrosoftAccessTable\",\"typeProperties\":{\"tableName\":\"databydlgfaphwu\"},\"description\":\"wtsaynrtvj\",\"structure\":\"datareeoxvq\",\"schema\":\"datarnbli\",\"linkedServiceName\":{\"referenceName\":\"sdbfbmdiv\",\"parameters\":{\"jg\":\"datah\",\"aub\":\"datazmiaoaweacf\"}},\"parameters\":{\"dckhsq\":{\"type\":\"Float\",\"defaultValue\":\"datatcnxriqz\"},\"okohlsfj\":{\"type\":\"Array\",\"defaultValue\":\"datajsurnowobwxrxm\"}},\"annotations\":[\"dataqjpzhe\",\"datahuv\"],\"folder\":{\"name\":\"qkvadmjhymud\"},\"\":{\"rmclyqwwu\":\"dataajzdebhs\",\"svkb\":\"datayqkaaptb\",\"bloccu\":\"databptw\",\"uybutcdzjfjt\":\"dataplxzbnsshvqnpszb\"}}")
.toObject(MicrosoftAccessTableDataset.class);
- Assertions.assertEquals("cklzhznfgvlxy", model.description());
- Assertions.assertEquals("tqjytdc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xyfhxohzbzhhavzf").type());
- Assertions.assertEquals("rmhbtofcv", model.folder().name());
+ Assertions.assertEquals("wtsaynrtvj", model.description());
+ Assertions.assertEquals("sdbfbmdiv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("dckhsq").type());
+ Assertions.assertEquals("qkvadmjhymud", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MicrosoftAccessTableDataset model = new MicrosoftAccessTableDataset().withDescription("cklzhznfgvlxy")
- .withStructure("datanctigpksywi")
- .withSchema("datalktgkdp")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tqjytdc")
- .withParameters(mapOf("gmlamoaxc", "datauhbdwbvjs", "kvbpbl", "dataytn", "exheeocnqo", "datacw")))
- .withParameters(mapOf("xyfhxohzbzhhavzf",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datavlryszfh"),
- "cofuvtfu", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datavkds"),
- "subzsspmj",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datauisaklhjfddxqfu"),
- "wbztrt",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datalfauyvxpqwlkqd")))
- .withAnnotations(Arrays.asList("datawvoglff", "datadhg"))
- .withFolder(new DatasetFolder().withName("rmhbtofcv"))
- .withTableName("datanrkbnv");
+ MicrosoftAccessTableDataset model = new MicrosoftAccessTableDataset().withDescription("wtsaynrtvj")
+ .withStructure("datareeoxvq")
+ .withSchema("datarnbli")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("sdbfbmdiv")
+ .withParameters(mapOf("jg", "datah", "aub", "datazmiaoaweacf")))
+ .withParameters(mapOf("dckhsq",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datatcnxriqz"), "okohlsfj",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datajsurnowobwxrxm")))
+ .withAnnotations(Arrays.asList("dataqjpzhe", "datahuv"))
+ .withFolder(new DatasetFolder().withName("qkvadmjhymud"))
+ .withTableName("databydlgfaphwu");
model = BinaryData.fromObject(model).toObject(MicrosoftAccessTableDataset.class);
- Assertions.assertEquals("cklzhznfgvlxy", model.description());
- Assertions.assertEquals("tqjytdc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xyfhxohzbzhhavzf").type());
- Assertions.assertEquals("rmhbtofcv", model.folder().name());
+ Assertions.assertEquals("wtsaynrtvj", model.description());
+ Assertions.assertEquals("sdbfbmdiv", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("dckhsq").type());
+ Assertions.assertEquals("qkvadmjhymud", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTypePropertiesTests.java
index a58660ea54f0..a2667a3e40e2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MicrosoftAccessTableDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class MicrosoftAccessTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- MicrosoftAccessTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datatmsgkwedwl\"}")
+ MicrosoftAccessTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"dataeyxdyu\"}")
.toObject(MicrosoftAccessTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
MicrosoftAccessTableDatasetTypeProperties model
- = new MicrosoftAccessTableDatasetTypeProperties().withTableName("datatmsgkwedwl");
+ = new MicrosoftAccessTableDatasetTypeProperties().withTableName("dataeyxdyu");
model = BinaryData.fromObject(model).toObject(MicrosoftAccessTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTests.java
index 06ded7576723..e65f0f3f2cdb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTests.java
@@ -19,33 +19,32 @@ public final class MongoDbAtlasCollectionDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbAtlasCollectionDataset model = BinaryData.fromString(
- "{\"type\":\"MongoDbAtlasCollection\",\"typeProperties\":{\"collection\":\"datapypkennycntrq\"},\"description\":\"wtdmb\",\"structure\":\"datatsuhqhtoxtd\",\"schema\":\"dataavfxbqmzxsya\",\"linkedServiceName\":{\"referenceName\":\"sinpaamihwbghvw\",\"parameters\":{\"qbjsdjpgxeysgw\":\"databgchcgsfzhbjkiy\",\"ivoveomkhfeqcoop\":\"datacfferznzc\",\"nbz\":\"datafpohimgckycjpeeb\"}},\"parameters\":{\"pbmxooqoh\":{\"type\":\"Float\",\"defaultValue\":\"dataout\"},\"upf\":{\"type\":\"SecureString\",\"defaultValue\":\"datacdmwk\"}},\"annotations\":[\"datad\",\"datadzauiunyev\",\"datayzdsytcikswhcam\",\"datauynfxkcgsfcmvh\"],\"folder\":{\"name\":\"pba\"},\"\":{\"owggx\":\"datarkljqkqwsyjtvj\",\"kteiidlbovwbclpr\":\"datawwdmbyp\",\"cnerekyjul\":\"dataeganihk\",\"qlq\":\"datakwwnq\"}}")
+ "{\"type\":\"MongoDbAtlasCollection\",\"typeProperties\":{\"collection\":\"datadwhslxebaj\"},\"description\":\"knmstbdoprwkamp\",\"structure\":\"datawpbldz\",\"schema\":\"dataudrcycm\",\"linkedServiceName\":{\"referenceName\":\"huzymhlhihqk\",\"parameters\":{\"aiildcpud\":\"datakmnbzko\",\"drobujnjgy\":\"datahquxsyjofpgv\",\"njgcp\":\"datauxmqxigidul\",\"ghxhkyqzjsdkpvn\":\"datakgrhnytslgsazuqz\"}},\"parameters\":{\"hflyuvbgtz\":{\"type\":\"Array\",\"defaultValue\":\"dataffxsfybntmveh\"}},\"annotations\":[\"dataweuydyb\",\"dataairvhpqsv\"],\"folder\":{\"name\":\"ogeatrcnqnvn\"},\"\":{\"iznzs\":\"datafcsjvjnk\"}}")
.toObject(MongoDbAtlasCollectionDataset.class);
- Assertions.assertEquals("wtdmb", model.description());
- Assertions.assertEquals("sinpaamihwbghvw", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("pbmxooqoh").type());
- Assertions.assertEquals("pba", model.folder().name());
+ Assertions.assertEquals("knmstbdoprwkamp", model.description());
+ Assertions.assertEquals("huzymhlhihqk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("hflyuvbgtz").type());
+ Assertions.assertEquals("ogeatrcnqnvn", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbAtlasCollectionDataset model = new MongoDbAtlasCollectionDataset().withDescription("wtdmb")
- .withStructure("datatsuhqhtoxtd")
- .withSchema("dataavfxbqmzxsya")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("sinpaamihwbghvw")
- .withParameters(mapOf("qbjsdjpgxeysgw", "databgchcgsfzhbjkiy", "ivoveomkhfeqcoop", "datacfferznzc",
- "nbz", "datafpohimgckycjpeeb")))
- .withParameters(mapOf("pbmxooqoh",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataout"), "upf",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datacdmwk")))
- .withAnnotations(Arrays.asList("datad", "datadzauiunyev", "datayzdsytcikswhcam", "datauynfxkcgsfcmvh"))
- .withFolder(new DatasetFolder().withName("pba"))
- .withCollection("datapypkennycntrq");
+ MongoDbAtlasCollectionDataset model = new MongoDbAtlasCollectionDataset().withDescription("knmstbdoprwkamp")
+ .withStructure("datawpbldz")
+ .withSchema("dataudrcycm")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("huzymhlhihqk")
+ .withParameters(mapOf("aiildcpud", "datakmnbzko", "drobujnjgy", "datahquxsyjofpgv", "njgcp",
+ "datauxmqxigidul", "ghxhkyqzjsdkpvn", "datakgrhnytslgsazuqz")))
+ .withParameters(mapOf("hflyuvbgtz",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataffxsfybntmveh")))
+ .withAnnotations(Arrays.asList("dataweuydyb", "dataairvhpqsv"))
+ .withFolder(new DatasetFolder().withName("ogeatrcnqnvn"))
+ .withCollection("datadwhslxebaj");
model = BinaryData.fromObject(model).toObject(MongoDbAtlasCollectionDataset.class);
- Assertions.assertEquals("wtdmb", model.description());
- Assertions.assertEquals("sinpaamihwbghvw", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("pbmxooqoh").type());
- Assertions.assertEquals("pba", model.folder().name());
+ Assertions.assertEquals("knmstbdoprwkamp", model.description());
+ Assertions.assertEquals("huzymhlhihqk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("hflyuvbgtz").type());
+ Assertions.assertEquals("ogeatrcnqnvn", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTypePropertiesTests.java
index b5a653ee8d97..bf1e75e37d03 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasCollectionDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class MongoDbAtlasCollectionDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- MongoDbAtlasCollectionDatasetTypeProperties model = BinaryData.fromString("{\"collection\":\"datapwxtvc\"}")
+ MongoDbAtlasCollectionDatasetTypeProperties model = BinaryData.fromString("{\"collection\":\"databiba\"}")
.toObject(MongoDbAtlasCollectionDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
MongoDbAtlasCollectionDatasetTypeProperties model
- = new MongoDbAtlasCollectionDatasetTypeProperties().withCollection("datapwxtvc");
+ = new MongoDbAtlasCollectionDatasetTypeProperties().withCollection("databiba");
model = BinaryData.fromObject(model).toObject(MongoDbAtlasCollectionDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTests.java
index fd2074af675e..b50adf81dfd3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTests.java
@@ -18,33 +18,36 @@ public final class MongoDbAtlasLinkedServiceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbAtlasLinkedService model = BinaryData.fromString(
- "{\"type\":\"MongoDbAtlas\",\"typeProperties\":{\"connectionString\":\"datarp\",\"database\":\"datasozaoutjliwbnw\",\"driverVersion\":\"datagbzjoyyptnok\"},\"version\":\"qxkzeowizvj\",\"connectVia\":{\"referenceName\":\"zxkflz\",\"parameters\":{\"wgnwhldctn\":\"dataxxboauvkkc\",\"mtnlcvl\":\"datachuqmdy\"}},\"description\":\"vhedrbz\",\"parameters\":{\"dkdlxd\":{\"type\":\"Int\",\"defaultValue\":\"datagwxwc\"},\"j\":{\"type\":\"String\",\"defaultValue\":\"dataalz\"},\"oypqussxi\":{\"type\":\"SecureString\",\"defaultValue\":\"datayxow\"}},\"annotations\":[\"datacrsdgtj\",\"datalop\"],\"\":{\"prszehijlwrfea\":\"dataaxt\",\"qaklsfx\":\"datazjpghjmgpc\",\"mfqmvnhsfjxt\":\"datarxix\"}}")
+ "{\"type\":\"MongoDbAtlas\",\"typeProperties\":{\"connectionString\":\"datankic\",\"database\":\"datamrwc\",\"driverVersion\":\"datanjcvew\"},\"version\":\"jrnaktj\",\"connectVia\":{\"referenceName\":\"iglahheqj\",\"parameters\":{\"v\":\"datarrxmcztrqnuahhke\",\"cyulwzjorvsgmkk\":\"datarbdujpshiszivr\"}},\"description\":\"esbj\",\"parameters\":{\"sdfslaektn\":{\"type\":\"Float\",\"defaultValue\":\"dataybrlwdm\"},\"qumexnpoaer\":{\"type\":\"Int\",\"defaultValue\":\"datalipvq\"},\"q\":{\"type\":\"String\",\"defaultValue\":\"datafhltwlzlmpiprlc\"},\"apepwpbnjckowtu\":{\"type\":\"Array\",\"defaultValue\":\"datanwyhqlybmkmxusmk\"}},\"annotations\":[\"datamysv\"],\"\":{\"ypmmyrggsdouzoh\":\"datallbwnmvhb\",\"wyqsxe\":\"datahq\"}}")
.toObject(MongoDbAtlasLinkedService.class);
- Assertions.assertEquals("qxkzeowizvj", model.version());
- Assertions.assertEquals("zxkflz", model.connectVia().referenceName());
- Assertions.assertEquals("vhedrbz", model.description());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("dkdlxd").type());
+ Assertions.assertEquals("jrnaktj", model.version());
+ Assertions.assertEquals("iglahheqj", model.connectVia().referenceName());
+ Assertions.assertEquals("esbj", model.description());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("sdfslaektn").type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbAtlasLinkedService model = new MongoDbAtlasLinkedService().withVersion("qxkzeowizvj")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("zxkflz")
- .withParameters(mapOf("wgnwhldctn", "dataxxboauvkkc", "mtnlcvl", "datachuqmdy")))
- .withDescription("vhedrbz")
- .withParameters(mapOf("dkdlxd",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datagwxwc"), "j",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataalz"), "oypqussxi",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datayxow")))
- .withAnnotations(Arrays.asList("datacrsdgtj", "datalop"))
- .withConnectionString("datarp")
- .withDatabase("datasozaoutjliwbnw")
- .withDriverVersion("datagbzjoyyptnok");
+ MongoDbAtlasLinkedService model = new MongoDbAtlasLinkedService().withVersion("jrnaktj")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("iglahheqj")
+ .withParameters(mapOf("v", "datarrxmcztrqnuahhke", "cyulwzjorvsgmkk", "datarbdujpshiszivr")))
+ .withDescription("esbj")
+ .withParameters(mapOf("sdfslaektn",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataybrlwdm"),
+ "qumexnpoaer", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datalipvq"),
+ "q",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datafhltwlzlmpiprlc"),
+ "apepwpbnjckowtu",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanwyhqlybmkmxusmk")))
+ .withAnnotations(Arrays.asList("datamysv"))
+ .withConnectionString("datankic")
+ .withDatabase("datamrwc")
+ .withDriverVersion("datanjcvew");
model = BinaryData.fromObject(model).toObject(MongoDbAtlasLinkedService.class);
- Assertions.assertEquals("qxkzeowizvj", model.version());
- Assertions.assertEquals("zxkflz", model.connectVia().referenceName());
- Assertions.assertEquals("vhedrbz", model.description());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("dkdlxd").type());
+ Assertions.assertEquals("jrnaktj", model.version());
+ Assertions.assertEquals("iglahheqj", model.connectVia().referenceName());
+ Assertions.assertEquals("esbj", model.description());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("sdfslaektn").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTypePropertiesTests.java
index 91481544739a..3573904bebc2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasLinkedServiceTypePropertiesTests.java
@@ -11,16 +11,16 @@ public final class MongoDbAtlasLinkedServiceTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbAtlasLinkedServiceTypeProperties model = BinaryData.fromString(
- "{\"connectionString\":\"datasbjxpuokkdpts\",\"database\":\"datapg\",\"driverVersion\":\"datalonalpwaulkwuy\"}")
+ "{\"connectionString\":\"datatltlmczcxouane\",\"database\":\"dataepgqztakovslv\",\"driverVersion\":\"datavdmtfcs\"}")
.toObject(MongoDbAtlasLinkedServiceTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
MongoDbAtlasLinkedServiceTypeProperties model
- = new MongoDbAtlasLinkedServiceTypeProperties().withConnectionString("datasbjxpuokkdpts")
- .withDatabase("datapg")
- .withDriverVersion("datalonalpwaulkwuy");
+ = new MongoDbAtlasLinkedServiceTypeProperties().withConnectionString("datatltlmczcxouane")
+ .withDatabase("dataepgqztakovslv")
+ .withDriverVersion("datavdmtfcs");
model = BinaryData.fromObject(model).toObject(MongoDbAtlasLinkedServiceTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSinkTests.java
index 054c196b8829..ab1b65d5cec6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSinkTests.java
@@ -11,19 +11,19 @@ public final class MongoDbAtlasSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbAtlasSink model = BinaryData.fromString(
- "{\"type\":\"MongoDbAtlasSink\",\"writeBehavior\":\"dataqusv\",\"writeBatchSize\":\"datagfzbykap\",\"writeBatchTimeout\":\"dataomc\",\"sinkRetryCount\":\"datam\",\"sinkRetryWait\":\"datadtg\",\"maxConcurrentConnections\":\"datayubnwymyewbfoxw\",\"disableMetricsCollection\":\"dataetj\",\"\":{\"tksrdjhqcrmptj\":\"databahxyfddp\",\"zadflvbkhg\":\"dataixawipjracyx\"}}")
+ "{\"type\":\"MongoDbAtlasSink\",\"writeBehavior\":\"datamkfvsolkjowvz\",\"writeBatchSize\":\"datae\",\"writeBatchTimeout\":\"dataj\",\"sinkRetryCount\":\"datayguothnucqktu\",\"sinkRetryWait\":\"datar\",\"maxConcurrentConnections\":\"datatpriicte\",\"disableMetricsCollection\":\"datalbahmivtuph\",\"\":{\"o\":\"datai\"}}")
.toObject(MongoDbAtlasSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbAtlasSink model = new MongoDbAtlasSink().withWriteBatchSize("datagfzbykap")
- .withWriteBatchTimeout("dataomc")
- .withSinkRetryCount("datam")
- .withSinkRetryWait("datadtg")
- .withMaxConcurrentConnections("datayubnwymyewbfoxw")
- .withDisableMetricsCollection("dataetj")
- .withWriteBehavior("dataqusv");
+ MongoDbAtlasSink model = new MongoDbAtlasSink().withWriteBatchSize("datae")
+ .withWriteBatchTimeout("dataj")
+ .withSinkRetryCount("datayguothnucqktu")
+ .withSinkRetryWait("datar")
+ .withMaxConcurrentConnections("datatpriicte")
+ .withDisableMetricsCollection("datalbahmivtuph")
+ .withWriteBehavior("datamkfvsolkjowvz");
model = BinaryData.fromObject(model).toObject(MongoDbAtlasSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSourceTests.java
index 6d220db1fc4f..afc8bf2815ff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbAtlasSourceTests.java
@@ -14,25 +14,25 @@ public final class MongoDbAtlasSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbAtlasSource model = BinaryData.fromString(
- "{\"type\":\"MongoDbAtlasSource\",\"filter\":\"datahiuwv\",\"cursorMethods\":{\"project\":\"dataejytqn\",\"sort\":\"datacbhayhctjvl\",\"skip\":\"datanzgzfs\",\"limit\":\"datavyt\",\"\":{\"uhsmuclx\":\"datadcwbaiaqq\",\"hzhervvlibro\":\"datacedusuyqcvykags\"}},\"batchSize\":\"dataxloedj\",\"queryTimeout\":\"datavfrfsyqbf\",\"additionalColumns\":\"dataujwowthvuepsz\",\"sourceRetryCount\":\"datavdjnspy\",\"sourceRetryWait\":\"dataoygutqtjwiv\",\"maxConcurrentConnections\":\"datamavfzjwdww\",\"disableMetricsCollection\":\"dataxehndcpiwcgcwmsh\",\"\":{\"xopzclka\":\"dataxjxhdwj\",\"mga\":\"datapu\"}}")
+ "{\"type\":\"MongoDbAtlasSource\",\"filter\":\"dataqexd\",\"cursorMethods\":{\"project\":\"datavkwwjjotfunsdu\",\"sort\":\"dataxvrwalek\",\"skip\":\"datadofuob\",\"limit\":\"datalainzvhl\",\"\":{\"lmihvzdaycmen\":\"dataib\",\"l\":\"datagzy\",\"jdotpcvddfmflwf\":\"datalvgqlexwqwbbell\"}},\"batchSize\":\"datakpwdpmygacu\",\"queryTimeout\":\"datahtwxifudlrxb\",\"additionalColumns\":\"dataftpvgmqzitc\",\"sourceRetryCount\":\"datamlltas\",\"sourceRetryWait\":\"dataqsf\",\"maxConcurrentConnections\":\"datae\",\"disableMetricsCollection\":\"dataveg\",\"\":{\"xisa\":\"datamyvgmbirvvvrb\",\"bridagwuvcdymoqv\":\"dataktuxwzvlh\",\"hrygw\":\"datajkrynziudmhe\"}}")
.toObject(MongoDbAtlasSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbAtlasSource model = new MongoDbAtlasSource().withSourceRetryCount("datavdjnspy")
- .withSourceRetryWait("dataoygutqtjwiv")
- .withMaxConcurrentConnections("datamavfzjwdww")
- .withDisableMetricsCollection("dataxehndcpiwcgcwmsh")
- .withFilter("datahiuwv")
- .withCursorMethods(new MongoDbCursorMethodsProperties().withProject("dataejytqn")
- .withSort("datacbhayhctjvl")
- .withSkip("datanzgzfs")
- .withLimit("datavyt")
+ MongoDbAtlasSource model = new MongoDbAtlasSource().withSourceRetryCount("datamlltas")
+ .withSourceRetryWait("dataqsf")
+ .withMaxConcurrentConnections("datae")
+ .withDisableMetricsCollection("dataveg")
+ .withFilter("dataqexd")
+ .withCursorMethods(new MongoDbCursorMethodsProperties().withProject("datavkwwjjotfunsdu")
+ .withSort("dataxvrwalek")
+ .withSkip("datadofuob")
+ .withLimit("datalainzvhl")
.withAdditionalProperties(mapOf()))
- .withBatchSize("dataxloedj")
- .withQueryTimeout("datavfrfsyqbf")
- .withAdditionalColumns("dataujwowthvuepsz");
+ .withBatchSize("datakpwdpmygacu")
+ .withQueryTimeout("datahtwxifudlrxb")
+ .withAdditionalColumns("dataftpvgmqzitc");
model = BinaryData.fromObject(model).toObject(MongoDbAtlasSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTests.java
index 38f4e5e8c24a..22db504fda02 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTests.java
@@ -19,32 +19,31 @@ public final class MongoDbCollectionDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbCollectionDataset model = BinaryData.fromString(
- "{\"type\":\"MongoDbCollection\",\"typeProperties\":{\"collectionName\":\"datao\"},\"description\":\"wbwggijts\",\"structure\":\"datajnrrhikws\",\"schema\":\"datar\",\"linkedServiceName\":{\"referenceName\":\"d\",\"parameters\":{\"zfrunjfhrjhiycba\":\"datauhtr\",\"hvtuwyjsqwzsz\":\"dataseqnczkv\"}},\"parameters\":{\"hczavojmsl\":{\"type\":\"SecureString\",\"defaultValue\":\"datazunkfnyskwwun\"}},\"annotations\":[\"datacukvbljpxprrvchy\"],\"folder\":{\"name\":\"alpcufjjfxtiztq\"},\"\":{\"wbaaes\":\"dataahhhsaaxxsritr\",\"bgpasrvrmti\":\"datayefmxwoqotii\"}}")
+ "{\"type\":\"MongoDbCollection\",\"typeProperties\":{\"collectionName\":\"datab\"},\"description\":\"wxs\",\"structure\":\"datajgg\",\"schema\":\"datagaef\",\"linkedServiceName\":{\"referenceName\":\"awkmibu\",\"parameters\":{\"updyttqm\":\"dataiurni\"}},\"parameters\":{\"s\":{\"type\":\"Array\",\"defaultValue\":\"datal\"}},\"annotations\":[\"datahhtuqmtxynof\",\"dataqobfixngxebihe\"],\"folder\":{\"name\":\"kingiqcdolrpgu\"},\"\":{\"dafbncuy\":\"datalbsm\",\"fzxjzi\":\"dataeykcnhpplzh\",\"wnuwkkfzzetl\":\"dataucrln\",\"vwywjvrlgqpwwlzp\":\"datahdyxz\"}}")
.toObject(MongoDbCollectionDataset.class);
- Assertions.assertEquals("wbwggijts", model.description());
- Assertions.assertEquals("d", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("hczavojmsl").type());
- Assertions.assertEquals("alpcufjjfxtiztq", model.folder().name());
+ Assertions.assertEquals("wxs", model.description());
+ Assertions.assertEquals("awkmibu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("s").type());
+ Assertions.assertEquals("kingiqcdolrpgu", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbCollectionDataset model = new MongoDbCollectionDataset().withDescription("wbwggijts")
- .withStructure("datajnrrhikws")
- .withSchema("datar")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("d")
- .withParameters(mapOf("zfrunjfhrjhiycba", "datauhtr", "hvtuwyjsqwzsz", "dataseqnczkv")))
- .withParameters(mapOf("hczavojmsl",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("datazunkfnyskwwun")))
- .withAnnotations(Arrays.asList("datacukvbljpxprrvchy"))
- .withFolder(new DatasetFolder().withName("alpcufjjfxtiztq"))
- .withCollectionName("datao");
+ MongoDbCollectionDataset model = new MongoDbCollectionDataset().withDescription("wxs")
+ .withStructure("datajgg")
+ .withSchema("datagaef")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("awkmibu")
+ .withParameters(mapOf("updyttqm", "dataiurni")))
+ .withParameters(
+ mapOf("s", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datal")))
+ .withAnnotations(Arrays.asList("datahhtuqmtxynof", "dataqobfixngxebihe"))
+ .withFolder(new DatasetFolder().withName("kingiqcdolrpgu"))
+ .withCollectionName("datab");
model = BinaryData.fromObject(model).toObject(MongoDbCollectionDataset.class);
- Assertions.assertEquals("wbwggijts", model.description());
- Assertions.assertEquals("d", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("hczavojmsl").type());
- Assertions.assertEquals("alpcufjjfxtiztq", model.folder().name());
+ Assertions.assertEquals("wxs", model.description());
+ Assertions.assertEquals("awkmibu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("s").type());
+ Assertions.assertEquals("kingiqcdolrpgu", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTypePropertiesTests.java
index 6d8d20ca689a..8a84eb09b942 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCollectionDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class MongoDbCollectionDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- MongoDbCollectionDatasetTypeProperties model = BinaryData.fromString("{\"collectionName\":\"datatyikjhorlx\"}")
+ MongoDbCollectionDatasetTypeProperties model = BinaryData.fromString("{\"collectionName\":\"datadarcb\"}")
.toObject(MongoDbCollectionDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
MongoDbCollectionDatasetTypeProperties model
- = new MongoDbCollectionDatasetTypeProperties().withCollectionName("datatyikjhorlx");
+ = new MongoDbCollectionDatasetTypeProperties().withCollectionName("datadarcb");
model = BinaryData.fromObject(model).toObject(MongoDbCollectionDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCursorMethodsPropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCursorMethodsPropertiesTests.java
index 374b541cd859..4eeffaa95ead 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCursorMethodsPropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbCursorMethodsPropertiesTests.java
@@ -13,16 +13,16 @@ public final class MongoDbCursorMethodsPropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbCursorMethodsProperties model = BinaryData.fromString(
- "{\"project\":\"datac\",\"sort\":\"datajjfmzv\",\"skip\":\"databflyzc\",\"limit\":\"datamlybsy\",\"\":{\"bt\":\"datanvtvbfpuml\"}}")
+ "{\"project\":\"datavuiox\",\"sort\":\"dataztrfot\",\"skip\":\"datafzcvhfnbccffsb\",\"limit\":\"databt\",\"\":{\"j\":\"datal\",\"chpzv\":\"dataoudjcttav\",\"lferjwhonn\":\"dataz\"}}")
.toObject(MongoDbCursorMethodsProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbCursorMethodsProperties model = new MongoDbCursorMethodsProperties().withProject("datac")
- .withSort("datajjfmzv")
- .withSkip("databflyzc")
- .withLimit("datamlybsy")
+ MongoDbCursorMethodsProperties model = new MongoDbCursorMethodsProperties().withProject("datavuiox")
+ .withSort("dataztrfot")
+ .withSkip("datafzcvhfnbccffsb")
+ .withLimit("databt")
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(MongoDbCursorMethodsProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbSourceTests.java
index 4f732b229260..b17136def71f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbSourceTests.java
@@ -11,18 +11,18 @@ public final class MongoDbSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbSource model = BinaryData.fromString(
- "{\"type\":\"MongoDbSource\",\"query\":\"databymnfctorqzb\",\"additionalColumns\":\"dataygfqqrar\",\"sourceRetryCount\":\"dataczahbynl\",\"sourceRetryWait\":\"datacnnfpfgstdif\",\"maxConcurrentConnections\":\"datafjslehge\",\"disableMetricsCollection\":\"datagsojtzarli\",\"\":{\"i\":\"datatvq\",\"xxuuqcmunhfarbg\":\"datasjh\",\"howw\":\"datayvypuio\",\"yw\":\"datar\"}}")
+ "{\"type\":\"MongoDbSource\",\"query\":\"dataomapcaxnoqnjfv\",\"additionalColumns\":\"datavectooxjztt\",\"sourceRetryCount\":\"datasnmxvsrvkzvxlez\",\"sourceRetryWait\":\"datadybxehjkqogtnfla\",\"maxConcurrentConnections\":\"datapghfvkqijmyqo\",\"disableMetricsCollection\":\"datasfaoc\",\"\":{\"dpyohnmru\":\"datarr\",\"eywbhxhawkwcf\":\"datavlwhtfscoups\"}}")
.toObject(MongoDbSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbSource model = new MongoDbSource().withSourceRetryCount("dataczahbynl")
- .withSourceRetryWait("datacnnfpfgstdif")
- .withMaxConcurrentConnections("datafjslehge")
- .withDisableMetricsCollection("datagsojtzarli")
- .withQuery("databymnfctorqzb")
- .withAdditionalColumns("dataygfqqrar");
+ MongoDbSource model = new MongoDbSource().withSourceRetryCount("datasnmxvsrvkzvxlez")
+ .withSourceRetryWait("datadybxehjkqogtnfla")
+ .withMaxConcurrentConnections("datapghfvkqijmyqo")
+ .withDisableMetricsCollection("datasfaoc")
+ .withQuery("dataomapcaxnoqnjfv")
+ .withAdditionalColumns("datavectooxjztt");
model = BinaryData.fromObject(model).toObject(MongoDbSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTests.java
index 23ad95126cf1..a0fcaca01d7d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTests.java
@@ -19,35 +19,34 @@ public final class MongoDbV2CollectionDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbV2CollectionDataset model = BinaryData.fromString(
- "{\"type\":\"MongoDbV2Collection\",\"typeProperties\":{\"collection\":\"databav\"},\"description\":\"vxwve\",\"structure\":\"datanlrjcsmwevguyfln\",\"schema\":\"datalr\",\"linkedServiceName\":{\"referenceName\":\"kfzcdetowwezhy\",\"parameters\":{\"csfqbirtybce\":\"datailbwqlq\"}},\"parameters\":{\"el\":{\"type\":\"Array\",\"defaultValue\":\"dataodnjyhzfaxskdv\"},\"qxsorchaz\":{\"type\":\"SecureString\",\"defaultValue\":\"datadpe\"},\"hlbeqvhs\":{\"type\":\"String\",\"defaultValue\":\"dataxz\"},\"gf\":{\"type\":\"Array\",\"defaultValue\":\"datapwxslaj\"}},\"annotations\":[\"dataefhawkmibuyd\"],\"folder\":{\"name\":\"rnicupdyttqmi\"},\"\":{\"xynof\":\"dataplosebmhhtuqm\",\"hnkingiqcdol\":\"dataqobfixngxebihe\",\"jlbsmndafbncuyj\":\"datapgup\"}}")
+ "{\"type\":\"MongoDbV2Collection\",\"typeProperties\":{\"collection\":\"dataugico\"},\"description\":\"tmvwrmjxyvuodnx\",\"structure\":\"databassqfyylwpp\",\"schema\":\"datagkbzbloas\",\"linkedServiceName\":{\"referenceName\":\"bxhqvovdp\",\"parameters\":{\"aqg\":\"datatuvsqjsrvjnq\",\"wevsfgdrmnszdosm\":\"dataqbfkceincnrecjbi\"}},\"parameters\":{\"hgsulwvgs\":{\"type\":\"Object\",\"defaultValue\":\"datazvmxtcwghndae\"},\"wuhyzekypy\":{\"type\":\"Array\",\"defaultValue\":\"dataigvfjjuzkilmc\"},\"bp\":{\"type\":\"Bool\",\"defaultValue\":\"datajlbzdlb\"}},\"annotations\":[\"datapzy\",\"dataov\",\"datanwbhanzgesfhshag\"],\"folder\":{\"name\":\"nezpby\"},\"\":{\"qbugihcdv\":\"dataynpmggqgagen\",\"zsaxzgkqwvdepp\":\"dataoizorbloe\"}}")
.toObject(MongoDbV2CollectionDataset.class);
- Assertions.assertEquals("vxwve", model.description());
- Assertions.assertEquals("kfzcdetowwezhy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("el").type());
- Assertions.assertEquals("rnicupdyttqmi", model.folder().name());
+ Assertions.assertEquals("tmvwrmjxyvuodnx", model.description());
+ Assertions.assertEquals("bxhqvovdp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("hgsulwvgs").type());
+ Assertions.assertEquals("nezpby", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbV2CollectionDataset model = new MongoDbV2CollectionDataset().withDescription("vxwve")
- .withStructure("datanlrjcsmwevguyfln")
- .withSchema("datalr")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("kfzcdetowwezhy")
- .withParameters(mapOf("csfqbirtybce", "datailbwqlq")))
- .withParameters(mapOf("el",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataodnjyhzfaxskdv"),
- "qxsorchaz",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datadpe"),
- "hlbeqvhs", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataxz"),
- "gf", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datapwxslaj")))
- .withAnnotations(Arrays.asList("dataefhawkmibuyd"))
- .withFolder(new DatasetFolder().withName("rnicupdyttqmi"))
- .withCollection("databav");
+ MongoDbV2CollectionDataset model = new MongoDbV2CollectionDataset().withDescription("tmvwrmjxyvuodnx")
+ .withStructure("databassqfyylwpp")
+ .withSchema("datagkbzbloas")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bxhqvovdp")
+ .withParameters(mapOf("aqg", "datatuvsqjsrvjnq", "wevsfgdrmnszdosm", "dataqbfkceincnrecjbi")))
+ .withParameters(mapOf("hgsulwvgs",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datazvmxtcwghndae"),
+ "wuhyzekypy",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataigvfjjuzkilmc"), "bp",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datajlbzdlb")))
+ .withAnnotations(Arrays.asList("datapzy", "dataov", "datanwbhanzgesfhshag"))
+ .withFolder(new DatasetFolder().withName("nezpby"))
+ .withCollection("dataugico");
model = BinaryData.fromObject(model).toObject(MongoDbV2CollectionDataset.class);
- Assertions.assertEquals("vxwve", model.description());
- Assertions.assertEquals("kfzcdetowwezhy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("el").type());
- Assertions.assertEquals("rnicupdyttqmi", model.folder().name());
+ Assertions.assertEquals("tmvwrmjxyvuodnx", model.description());
+ Assertions.assertEquals("bxhqvovdp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("hgsulwvgs").type());
+ Assertions.assertEquals("nezpby", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTypePropertiesTests.java
index a798a9a13524..db1b0c6ec4e2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2CollectionDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class MongoDbV2CollectionDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- MongoDbV2CollectionDatasetTypeProperties model = BinaryData.fromString("{\"collection\":\"dataykcnhpplzhc\"}")
+ MongoDbV2CollectionDatasetTypeProperties model = BinaryData.fromString("{\"collection\":\"datanaphifkfrpmpl\"}")
.toObject(MongoDbV2CollectionDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
MongoDbV2CollectionDatasetTypeProperties model
- = new MongoDbV2CollectionDatasetTypeProperties().withCollection("dataykcnhpplzhc");
+ = new MongoDbV2CollectionDatasetTypeProperties().withCollection("datanaphifkfrpmpl");
model = BinaryData.fromObject(model).toObject(MongoDbV2CollectionDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTests.java
index a7f746f876b1..991981d262a7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTests.java
@@ -18,30 +18,34 @@ public final class MongoDbV2LinkedServiceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbV2LinkedService model = BinaryData.fromString(
- "{\"type\":\"MongoDbV2\",\"typeProperties\":{\"connectionString\":\"datasjwnwn\",\"database\":\"datad\"},\"version\":\"fgtmu\",\"connectVia\":{\"referenceName\":\"lhnxqvzzi\",\"parameters\":{\"eftugiwsvlf\":\"datafuwcajyezlkui\"}},\"description\":\"bpnrgnxwrfu\",\"parameters\":{\"qcjclvbqovkz\":{\"type\":\"Array\",\"defaultValue\":\"datafzuvuoxzy\"}},\"annotations\":[\"datatphnazpgv\",\"datacubxlmqh\",\"datadbqrlb\",\"datahzyfuupqkr\"],\"\":{\"vbkkgqf\":\"datajpc\",\"hw\":\"datawgphhpwx\",\"pxftyifadsliif\":\"datafqzwysmsqqmdajsq\",\"snxmfooin\":\"datarbsrpjspbi\"}}")
+ "{\"type\":\"MongoDbV2\",\"typeProperties\":{\"connectionString\":\"dataucmiqsdsnu\",\"database\":\"dataq\"},\"version\":\"qitiut\",\"connectVia\":{\"referenceName\":\"asxjkclzqpasril\",\"parameters\":{\"cvq\":\"datahlbhkijq\"}},\"description\":\"xrqiwxeppuhkizoa\",\"parameters\":{\"vfbmxzobpg\":{\"type\":\"String\",\"defaultValue\":\"datavob\"},\"ybyilhdbb\":{\"type\":\"Object\",\"defaultValue\":\"datalkpajio\"},\"choji\":{\"type\":\"Array\",\"defaultValue\":\"datauyxhcwubtego\"},\"frgiplxrifbsbk\":{\"type\":\"SecureString\",\"defaultValue\":\"dataq\"}},\"annotations\":[\"datav\",\"databbpoijs\",\"datavrutjituufknar\"],\"\":{\"smvnnjwnwo\":\"datanktpjinzosx\",\"xowppvuxqac\":\"datavezwwqc\",\"ir\":\"dataoqqehn\",\"tvnlbkizebbrwlp\":\"datagnvuolv\"}}")
.toObject(MongoDbV2LinkedService.class);
- Assertions.assertEquals("fgtmu", model.version());
- Assertions.assertEquals("lhnxqvzzi", model.connectVia().referenceName());
- Assertions.assertEquals("bpnrgnxwrfu", model.description());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("qcjclvbqovkz").type());
+ Assertions.assertEquals("qitiut", model.version());
+ Assertions.assertEquals("asxjkclzqpasril", model.connectVia().referenceName());
+ Assertions.assertEquals("xrqiwxeppuhkizoa", model.description());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("vfbmxzobpg").type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbV2LinkedService model = new MongoDbV2LinkedService().withVersion("fgtmu")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("lhnxqvzzi")
- .withParameters(mapOf("eftugiwsvlf", "datafuwcajyezlkui")))
- .withDescription("bpnrgnxwrfu")
- .withParameters(mapOf("qcjclvbqovkz",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datafzuvuoxzy")))
- .withAnnotations(Arrays.asList("datatphnazpgv", "datacubxlmqh", "datadbqrlb", "datahzyfuupqkr"))
- .withConnectionString("datasjwnwn")
- .withDatabase("datad");
+ MongoDbV2LinkedService model = new MongoDbV2LinkedService().withVersion("qitiut")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("asxjkclzqpasril")
+ .withParameters(mapOf("cvq", "datahlbhkijq")))
+ .withDescription("xrqiwxeppuhkizoa")
+ .withParameters(mapOf("vfbmxzobpg",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datavob"), "ybyilhdbb",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datalkpajio"), "choji",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datauyxhcwubtego"),
+ "frgiplxrifbsbk",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataq")))
+ .withAnnotations(Arrays.asList("datav", "databbpoijs", "datavrutjituufknar"))
+ .withConnectionString("dataucmiqsdsnu")
+ .withDatabase("dataq");
model = BinaryData.fromObject(model).toObject(MongoDbV2LinkedService.class);
- Assertions.assertEquals("fgtmu", model.version());
- Assertions.assertEquals("lhnxqvzzi", model.connectVia().referenceName());
- Assertions.assertEquals("bpnrgnxwrfu", model.description());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("qcjclvbqovkz").type());
+ Assertions.assertEquals("qitiut", model.version());
+ Assertions.assertEquals("asxjkclzqpasril", model.connectVia().referenceName());
+ Assertions.assertEquals("xrqiwxeppuhkizoa", model.description());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("vfbmxzobpg").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTypePropertiesTests.java
index dd418c0aded5..3b12a8f0885f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2LinkedServiceTypePropertiesTests.java
@@ -11,15 +11,15 @@ public final class MongoDbV2LinkedServiceTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbV2LinkedServiceTypeProperties model
- = BinaryData.fromString("{\"connectionString\":\"datanrfvqgcuwgk\",\"database\":\"dataqcbrewtfuxkts\"}")
+ = BinaryData.fromString("{\"connectionString\":\"dataqmisoiqge\",\"database\":\"datazgwywyxbwuam\"}")
.toObject(MongoDbV2LinkedServiceTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
MongoDbV2LinkedServiceTypeProperties model
- = new MongoDbV2LinkedServiceTypeProperties().withConnectionString("datanrfvqgcuwgk")
- .withDatabase("dataqcbrewtfuxkts");
+ = new MongoDbV2LinkedServiceTypeProperties().withConnectionString("dataqmisoiqge")
+ .withDatabase("datazgwywyxbwuam");
model = BinaryData.fromObject(model).toObject(MongoDbV2LinkedServiceTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SinkTests.java
index c09852c9751f..fd8d36795db2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SinkTests.java
@@ -11,19 +11,19 @@ public final class MongoDbV2SinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbV2Sink model = BinaryData.fromString(
- "{\"type\":\"MongoDbV2Sink\",\"writeBehavior\":\"datarcqdvapohe\",\"writeBatchSize\":\"datanerejrdxhl\",\"writeBatchTimeout\":\"datamxhztdcadbmvqgqm\",\"sinkRetryCount\":\"datarpagmhhwcyasz\",\"sinkRetryWait\":\"datahmtcihupoeljfni\",\"maxConcurrentConnections\":\"dataoxajitaaw\",\"disableMetricsCollection\":\"datadeqqbdcbnr\",\"\":{\"tnbmsopuwesmxod\":\"datanorymt\"}}")
+ "{\"type\":\"MongoDbV2Sink\",\"writeBehavior\":\"dataxfteomnrziw\",\"writeBatchSize\":\"datapxgjmyoufqa\",\"writeBatchTimeout\":\"dataaypcdikkmyrs\",\"sinkRetryCount\":\"datartxggmp\",\"sinkRetryWait\":\"datauvasxjzklqk\",\"maxConcurrentConnections\":\"dataukn\",\"disableMetricsCollection\":\"datanjhywgziqcwn\",\"\":{\"wnlauw\":\"dataehptl\"}}")
.toObject(MongoDbV2Sink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbV2Sink model = new MongoDbV2Sink().withWriteBatchSize("datanerejrdxhl")
- .withWriteBatchTimeout("datamxhztdcadbmvqgqm")
- .withSinkRetryCount("datarpagmhhwcyasz")
- .withSinkRetryWait("datahmtcihupoeljfni")
- .withMaxConcurrentConnections("dataoxajitaaw")
- .withDisableMetricsCollection("datadeqqbdcbnr")
- .withWriteBehavior("datarcqdvapohe");
+ MongoDbV2Sink model = new MongoDbV2Sink().withWriteBatchSize("datapxgjmyoufqa")
+ .withWriteBatchTimeout("dataaypcdikkmyrs")
+ .withSinkRetryCount("datartxggmp")
+ .withSinkRetryWait("datauvasxjzklqk")
+ .withMaxConcurrentConnections("dataukn")
+ .withDisableMetricsCollection("datanjhywgziqcwn")
+ .withWriteBehavior("dataxfteomnrziw");
model = BinaryData.fromObject(model).toObject(MongoDbV2Sink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SourceTests.java
index 215d303c9a4e..82166fba2a5b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MongoDbV2SourceTests.java
@@ -14,25 +14,25 @@ public final class MongoDbV2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MongoDbV2Source model = BinaryData.fromString(
- "{\"type\":\"MongoDbV2Source\",\"filter\":\"dataumuuqwcka\",\"cursorMethods\":{\"project\":\"datatdfzjwjefclihana\",\"sort\":\"datapdqozvvlqzopvhw\",\"skip\":\"datadbfrjvqvu\",\"limit\":\"dataps\",\"\":{\"jxkxl\":\"dataagordbsascntdw\",\"feqnmb\":\"dataowdwiffa\",\"tthsuzxyl\":\"datagcb\"}},\"batchSize\":\"dataf\",\"queryTimeout\":\"datas\",\"additionalColumns\":\"datanscobhhbljsvpok\",\"sourceRetryCount\":\"dataobygff\",\"sourceRetryWait\":\"datahnusrfffago\",\"maxConcurrentConnections\":\"datafwzysvnvrfjgbxup\",\"disableMetricsCollection\":\"datag\",\"\":{\"rowrmesziubkyvc\":\"datavwuje\",\"wdjbyaav\":\"datakoufwkaomytlx\",\"xyhuetztorhu\":\"datamsxamncuhxznma\"}}")
+ "{\"type\":\"MongoDbV2Source\",\"filter\":\"datadexnicq\",\"cursorMethods\":{\"project\":\"dataqttfqgdoowgqooip\",\"sort\":\"datasvsnedhkj\",\"skip\":\"datafvetwfreqvfl\",\"limit\":\"datatjuuikqzdcwqal\",\"\":{\"olkw\":\"dataiytpjisci\",\"lnodrfc\":\"datapvlsljutawg\",\"yxduxhopy\":\"dataehlopipvpeaeyj\",\"embvfa\":\"datavcbm\"}},\"batchSize\":\"dataxjoa\",\"queryTimeout\":\"dataxmumfbkaxzrycvac\",\"additionalColumns\":\"datazjysyphxeoqm\",\"sourceRetryCount\":\"datahikcei\",\"sourceRetryWait\":\"datavosb\",\"maxConcurrentConnections\":\"datawrbqooxvprq\",\"disableMetricsCollection\":\"dataqh\",\"\":{\"kif\":\"datapqrtnkngjnhxufoc\",\"tped\":\"dataj\",\"qqoz\":\"datahfpfsesiywcrejtp\",\"mfjktd\":\"dataesbpqw\"}}")
.toObject(MongoDbV2Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MongoDbV2Source model = new MongoDbV2Source().withSourceRetryCount("dataobygff")
- .withSourceRetryWait("datahnusrfffago")
- .withMaxConcurrentConnections("datafwzysvnvrfjgbxup")
- .withDisableMetricsCollection("datag")
- .withFilter("dataumuuqwcka")
- .withCursorMethods(new MongoDbCursorMethodsProperties().withProject("datatdfzjwjefclihana")
- .withSort("datapdqozvvlqzopvhw")
- .withSkip("datadbfrjvqvu")
- .withLimit("dataps")
+ MongoDbV2Source model = new MongoDbV2Source().withSourceRetryCount("datahikcei")
+ .withSourceRetryWait("datavosb")
+ .withMaxConcurrentConnections("datawrbqooxvprq")
+ .withDisableMetricsCollection("dataqh")
+ .withFilter("datadexnicq")
+ .withCursorMethods(new MongoDbCursorMethodsProperties().withProject("dataqttfqgdoowgqooip")
+ .withSort("datasvsnedhkj")
+ .withSkip("datafvetwfreqvfl")
+ .withLimit("datatjuuikqzdcwqal")
.withAdditionalProperties(mapOf()))
- .withBatchSize("dataf")
- .withQueryTimeout("datas")
- .withAdditionalColumns("datanscobhhbljsvpok");
+ .withBatchSize("dataxjoa")
+ .withQueryTimeout("dataxmumfbkaxzrycvac")
+ .withAdditionalColumns("datazjysyphxeoqm");
model = BinaryData.fromObject(model).toObject(MongoDbV2Source.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MultiplePipelineTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MultiplePipelineTriggerTests.java
index caf7eaea27a2..7f456b2d9347 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MultiplePipelineTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MultiplePipelineTriggerTests.java
@@ -17,24 +17,30 @@ public final class MultiplePipelineTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MultiplePipelineTrigger model = BinaryData.fromString(
- "{\"type\":\"MultiplePipelineTrigger\",\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"ieteznnlsqymv\",\"name\":\"hgpekzu\"},\"parameters\":{\"dcdrysanifcf\":\"datahyfiuxd\",\"epoantsrs\":\"datatijzsumgzebqbde\"}}],\"description\":\"eew\",\"runtimeState\":\"Started\",\"annotations\":[\"datalazunedso\",\"datajfi\",\"dataiti\",\"datawxcvwhutjjqzqi\"],\"\":{\"bjsrisfcc\":\"datao\"}}")
+ "{\"type\":\"MultiplePipelineTrigger\",\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"gr\",\"name\":\"lt\"},\"parameters\":{\"c\":\"dataqyiiujukcdlvptxt\",\"xpxslccuyscjefap\":\"datapmfpbodswgnglmll\",\"dndirdle\":\"datauwsyns\"}},{\"pipelineReference\":{\"referenceName\":\"zvpdwyhggv\",\"name\":\"oaoetitktkeir\"},\"parameters\":{\"up\":\"datafmsaedglubqtf\"}}],\"description\":\"wtemir\",\"runtimeState\":\"Started\",\"annotations\":[\"dataksafjht\",\"databrkghtsfp\",\"datajunkhxthkqny\"],\"\":{\"ceheeqqetasi\":\"datavzrqaphe\",\"qwomkzcmwqfd\":\"dataia\"}}")
.toObject(MultiplePipelineTrigger.class);
- Assertions.assertEquals("eew", model.description());
- Assertions.assertEquals("ieteznnlsqymv", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("hgpekzu", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("wtemir", model.description());
+ Assertions.assertEquals("gr", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("lt", model.pipelines().get(0).pipelineReference().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MultiplePipelineTrigger model = new MultiplePipelineTrigger().withDescription("eew")
- .withAnnotations(Arrays.asList("datalazunedso", "datajfi", "dataiti", "datawxcvwhutjjqzqi"))
- .withPipelines(Arrays.asList(new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("ieteznnlsqymv").withName("hgpekzu"))
- .withParameters(mapOf("dcdrysanifcf", "datahyfiuxd", "epoantsrs", "datatijzsumgzebqbde"))));
+ MultiplePipelineTrigger model = new MultiplePipelineTrigger().withDescription("wtemir")
+ .withAnnotations(Arrays.asList("dataksafjht", "databrkghtsfp", "datajunkhxthkqny"))
+ .withPipelines(Arrays.asList(
+ new TriggerPipelineReference()
+ .withPipelineReference(new PipelineReference().withReferenceName("gr").withName("lt"))
+ .withParameters(mapOf("c", "dataqyiiujukcdlvptxt", "xpxslccuyscjefap", "datapmfpbodswgnglmll",
+ "dndirdle", "datauwsyns")),
+ new TriggerPipelineReference()
+ .withPipelineReference(
+ new PipelineReference().withReferenceName("zvpdwyhggv").withName("oaoetitktkeir"))
+ .withParameters(mapOf("up", "datafmsaedglubqtf"))));
model = BinaryData.fromObject(model).toObject(MultiplePipelineTrigger.class);
- Assertions.assertEquals("eew", model.description());
- Assertions.assertEquals("ieteznnlsqymv", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("hgpekzu", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals("wtemir", model.description());
+ Assertions.assertEquals("gr", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("lt", model.pipelines().get(0).pipelineReference().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlSourceTests.java
index 227805e0c743..9247c20ba016 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlSourceTests.java
@@ -11,19 +11,19 @@ public final class MySqlSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MySqlSource model = BinaryData.fromString(
- "{\"type\":\"MySqlSource\",\"query\":\"datajwgejakuz\",\"queryTimeout\":\"datawn\",\"additionalColumns\":\"datac\",\"sourceRetryCount\":\"datajgsyszdtgwmqcutk\",\"sourceRetryWait\":\"datarourtmccdejtoypl\",\"maxConcurrentConnections\":\"datavjutckfhmdcvlb\",\"disableMetricsCollection\":\"dataezvujpbmz\",\"\":{\"zpfoispchhvvmvs\":\"datagmuhxwkkbnhmdtj\"}}")
+ "{\"type\":\"MySqlSource\",\"query\":\"datahoh\",\"queryTimeout\":\"databmxoowpoogozercc\",\"additionalColumns\":\"datap\",\"sourceRetryCount\":\"datakg\",\"sourceRetryWait\":\"datauj\",\"maxConcurrentConnections\":\"dataqjqafjk\",\"disableMetricsCollection\":\"datalogvfnwqzolva\",\"\":{\"g\":\"datakycge\"}}")
.toObject(MySqlSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MySqlSource model = new MySqlSource().withSourceRetryCount("datajgsyszdtgwmqcutk")
- .withSourceRetryWait("datarourtmccdejtoypl")
- .withMaxConcurrentConnections("datavjutckfhmdcvlb")
- .withDisableMetricsCollection("dataezvujpbmz")
- .withQueryTimeout("datawn")
- .withAdditionalColumns("datac")
- .withQuery("datajwgejakuz");
+ MySqlSource model = new MySqlSource().withSourceRetryCount("datakg")
+ .withSourceRetryWait("datauj")
+ .withMaxConcurrentConnections("dataqjqafjk")
+ .withDisableMetricsCollection("datalogvfnwqzolva")
+ .withQueryTimeout("databmxoowpoogozercc")
+ .withAdditionalColumns("datap")
+ .withQuery("datahoh");
model = BinaryData.fromObject(model).toObject(MySqlSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTests.java
index f045776d1bee..9c7f49e6fa34 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTests.java
@@ -19,35 +19,34 @@ public final class MySqlTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
MySqlTableDataset model = BinaryData.fromString(
- "{\"type\":\"MySqlTable\",\"typeProperties\":{\"tableName\":\"databtownoljdkx\"},\"description\":\"ewy\",\"structure\":\"datalclzxkrdpuy\",\"schema\":\"databpkrpk\",\"linkedServiceName\":{\"referenceName\":\"qetp\",\"parameters\":{\"fpc\":\"dataefno\",\"yrxowv\":\"datarx\"}},\"parameters\":{\"ozfrfawtnnsv\":{\"type\":\"Int\",\"defaultValue\":\"datauajwblxph\"},\"gzqzhluc\":{\"type\":\"Array\",\"defaultValue\":\"datajynihtibu\"},\"cgyo\":{\"type\":\"Float\",\"defaultValue\":\"datafehb\"},\"ebldxagmdfjwc\":{\"type\":\"String\",\"defaultValue\":\"datameqljxdumhycxo\"}},\"annotations\":[\"datawxjsjquv\"],\"folder\":{\"name\":\"fzdtsrpjuvgz\"},\"\":{\"huqczouanbfulv\":\"datazhnsbylgmg\"}}")
+ "{\"type\":\"MySqlTable\",\"typeProperties\":{\"tableName\":\"databgwzhbhflj\"},\"description\":\"od\",\"structure\":\"dataovnlhrwya\",\"schema\":\"datauafapwxsvdeatjio\",\"linkedServiceName\":{\"referenceName\":\"nirgoext\",\"parameters\":{\"tbsetko\":\"datawtgntimznupb\",\"aakghcrzmmmjyvdh\":\"datasqvhe\",\"etqjisjm\":\"datagdiwmlgstm\"}},\"parameters\":{\"kakhgkrv\":{\"type\":\"SecureString\",\"defaultValue\":\"dataq\"},\"ejqaw\":{\"type\":\"Object\",\"defaultValue\":\"datacvytv\"},\"pbbimh\":{\"type\":\"Float\",\"defaultValue\":\"dataqpfzxkczbd\"}},\"annotations\":[\"datazvoortc\",\"datanh\"],\"folder\":{\"name\":\"yuzly\"},\"\":{\"lkv\":\"datacibv\",\"nviulbylmgjzr\":\"datakcafnwqhawv\"}}")
.toObject(MySqlTableDataset.class);
- Assertions.assertEquals("ewy", model.description());
- Assertions.assertEquals("qetp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("ozfrfawtnnsv").type());
- Assertions.assertEquals("fzdtsrpjuvgz", model.folder().name());
+ Assertions.assertEquals("od", model.description());
+ Assertions.assertEquals("nirgoext", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("kakhgkrv").type());
+ Assertions.assertEquals("yuzly", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MySqlTableDataset model = new MySqlTableDataset().withDescription("ewy")
- .withStructure("datalclzxkrdpuy")
- .withSchema("databpkrpk")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qetp")
- .withParameters(mapOf("fpc", "dataefno", "yrxowv", "datarx")))
- .withParameters(mapOf("ozfrfawtnnsv",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datauajwblxph"), "gzqzhluc",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datajynihtibu"), "cgyo",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datafehb"),
- "ebldxagmdfjwc",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datameqljxdumhycxo")))
- .withAnnotations(Arrays.asList("datawxjsjquv"))
- .withFolder(new DatasetFolder().withName("fzdtsrpjuvgz"))
- .withTableName("databtownoljdkx");
+ MySqlTableDataset model = new MySqlTableDataset().withDescription("od")
+ .withStructure("dataovnlhrwya")
+ .withSchema("datauafapwxsvdeatjio")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("nirgoext")
+ .withParameters(mapOf("tbsetko", "datawtgntimznupb", "aakghcrzmmmjyvdh", "datasqvhe", "etqjisjm",
+ "datagdiwmlgstm")))
+ .withParameters(mapOf("kakhgkrv",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataq"), "ejqaw",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datacvytv"), "pbbimh",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqpfzxkczbd")))
+ .withAnnotations(Arrays.asList("datazvoortc", "datanh"))
+ .withFolder(new DatasetFolder().withName("yuzly"))
+ .withTableName("databgwzhbhflj");
model = BinaryData.fromObject(model).toObject(MySqlTableDataset.class);
- Assertions.assertEquals("ewy", model.description());
- Assertions.assertEquals("qetp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("ozfrfawtnnsv").type());
- Assertions.assertEquals("fzdtsrpjuvgz", model.folder().name());
+ Assertions.assertEquals("od", model.description());
+ Assertions.assertEquals("nirgoext", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("kakhgkrv").type());
+ Assertions.assertEquals("yuzly", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTypePropertiesTests.java
index 00b2c522cba2..0d791f816bda 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/MySqlTableDatasetTypePropertiesTests.java
@@ -10,14 +10,13 @@
public final class MySqlTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- MySqlTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"dataglxoqwbztilqb\"}")
+ MySqlTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datawpbgumwhmxp\"}")
.toObject(MySqlTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- MySqlTableDatasetTypeProperties model
- = new MySqlTableDatasetTypeProperties().withTableName("dataglxoqwbztilqb");
+ MySqlTableDatasetTypeProperties model = new MySqlTableDatasetTypeProperties().withTableName("datawpbgumwhmxp");
model = BinaryData.fromObject(model).toObject(MySqlTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaPartitionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaPartitionSettingsTests.java
index f16538618560..e3293758d3ef 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaPartitionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaPartitionSettingsTests.java
@@ -11,15 +11,15 @@ public final class NetezzaPartitionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
NetezzaPartitionSettings model = BinaryData.fromString(
- "{\"partitionColumnName\":\"datavkdnfg\",\"partitionUpperBound\":\"dataxultxhqqvdhdyy\",\"partitionLowerBound\":\"datatx\"}")
+ "{\"partitionColumnName\":\"datatfwkvirmbr\",\"partitionUpperBound\":\"datagnqa\",\"partitionLowerBound\":\"datak\"}")
.toObject(NetezzaPartitionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- NetezzaPartitionSettings model = new NetezzaPartitionSettings().withPartitionColumnName("datavkdnfg")
- .withPartitionUpperBound("dataxultxhqqvdhdyy")
- .withPartitionLowerBound("datatx");
+ NetezzaPartitionSettings model = new NetezzaPartitionSettings().withPartitionColumnName("datatfwkvirmbr")
+ .withPartitionUpperBound("datagnqa")
+ .withPartitionLowerBound("datak");
model = BinaryData.fromObject(model).toObject(NetezzaPartitionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaSourceTests.java
index 63a44930732d..ad638e2f5e03 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaSourceTests.java
@@ -12,23 +12,23 @@ public final class NetezzaSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
NetezzaSource model = BinaryData.fromString(
- "{\"type\":\"NetezzaSource\",\"query\":\"databuwauytq\",\"partitionOption\":\"datagaxloafws\",\"partitionSettings\":{\"partitionColumnName\":\"dataqr\",\"partitionUpperBound\":\"dataw\",\"partitionLowerBound\":\"dataipn\"},\"queryTimeout\":\"dataql\",\"additionalColumns\":\"datarhctbrvegdamoy\",\"sourceRetryCount\":\"datafjpkezqjizbyczme\",\"sourceRetryWait\":\"dataacgvlnpjjb\",\"maxConcurrentConnections\":\"datayrktuvdestarulnh\",\"disableMetricsCollection\":\"datatvyhsxhcrf\",\"\":{\"svzhlkeot\":\"dataexupcuizvx\",\"iy\":\"datascqkxzrfloqzmvem\",\"zhanvcf\":\"datadfqfnftrrhhgwaw\"}}")
+ "{\"type\":\"NetezzaSource\",\"query\":\"dataykx\",\"partitionOption\":\"dataympsxmoad\",\"partitionSettings\":{\"partitionColumnName\":\"datansmpfe\",\"partitionUpperBound\":\"datavl\",\"partitionLowerBound\":\"datasyvryo\"},\"queryTimeout\":\"dataqikcork\",\"additionalColumns\":\"dataobobxfhtb\",\"sourceRetryCount\":\"datavwzjycgcie\",\"sourceRetryWait\":\"datax\",\"maxConcurrentConnections\":\"datazvnghtknr\",\"disableMetricsCollection\":\"datahysnmyuvf\",\"\":{\"pxoelfobehr\":\"datanrapxwt\",\"lojjcz\":\"dataf\"}}")
.toObject(NetezzaSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- NetezzaSource model = new NetezzaSource().withSourceRetryCount("datafjpkezqjizbyczme")
- .withSourceRetryWait("dataacgvlnpjjb")
- .withMaxConcurrentConnections("datayrktuvdestarulnh")
- .withDisableMetricsCollection("datatvyhsxhcrf")
- .withQueryTimeout("dataql")
- .withAdditionalColumns("datarhctbrvegdamoy")
- .withQuery("databuwauytq")
- .withPartitionOption("datagaxloafws")
- .withPartitionSettings(new NetezzaPartitionSettings().withPartitionColumnName("dataqr")
- .withPartitionUpperBound("dataw")
- .withPartitionLowerBound("dataipn"));
+ NetezzaSource model = new NetezzaSource().withSourceRetryCount("datavwzjycgcie")
+ .withSourceRetryWait("datax")
+ .withMaxConcurrentConnections("datazvnghtknr")
+ .withDisableMetricsCollection("datahysnmyuvf")
+ .withQueryTimeout("dataqikcork")
+ .withAdditionalColumns("dataobobxfhtb")
+ .withQuery("dataykx")
+ .withPartitionOption("dataympsxmoad")
+ .withPartitionSettings(new NetezzaPartitionSettings().withPartitionColumnName("datansmpfe")
+ .withPartitionUpperBound("datavl")
+ .withPartitionLowerBound("datasyvryo"));
model = BinaryData.fromObject(model).toObject(NetezzaSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTests.java
index 6679ad677a3c..ac5a5da15eed 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTests.java
@@ -19,35 +19,39 @@ public final class NetezzaTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
NetezzaTableDataset model = BinaryData.fromString(
- "{\"type\":\"NetezzaTable\",\"typeProperties\":{\"tableName\":\"datadvfjd\",\"table\":\"dataephtoshqtuar\",\"schema\":\"datagujrcnxaeypyq\"},\"description\":\"zfyasyddqbws\",\"structure\":\"datawyyeomiflrvfe\",\"schema\":\"datactshwfrhhasabvau\",\"linkedServiceName\":{\"referenceName\":\"nwwumkbpg\",\"parameters\":{\"rpdgitenyuksli\":\"databwtpwbjlpfwuq\",\"amrplanch\":\"datampnxg\",\"z\":\"dataotmmxlmxejwyv\",\"sbeqieiuxhj\":\"datajwvtuekbbypqsm\"}},\"parameters\":{\"zyxvta\":{\"type\":\"String\",\"defaultValue\":\"datalnjjhrgkjjpcpih\"},\"urdgc\":{\"type\":\"Float\",\"defaultValue\":\"dataatoidne\"}},\"annotations\":[\"datanaqve\",\"datagnpuelrnanbrpkoc\",\"dataxfbagegjtjltcki\"],\"folder\":{\"name\":\"gfagijxmdbo\"},\"\":{\"invzsod\":\"datahxhahuq\"}}")
+ "{\"type\":\"NetezzaTable\",\"typeProperties\":{\"tableName\":\"datamblmfcleuov\",\"table\":\"datavspr\",\"schema\":\"datajtez\"},\"description\":\"toudodexwmvs\",\"structure\":\"datajciexuwemtgtgeb\",\"schema\":\"datamcgsks\",\"linkedServiceName\":{\"referenceName\":\"bsxehaxicjojxol\",\"parameters\":{\"mbglmnlbnatln\":\"datahgwakptb\",\"jk\":\"datahzzcdkxortdzzvhb\",\"dzccqtwsrbfbsd\":\"datahophqwo\",\"vexrvnhhmfsnq\":\"dataicdzf\"}},\"parameters\":{\"sdzmhwtsyppwf\":{\"type\":\"String\",\"defaultValue\":\"datahlwvrs\"},\"aypxsazbxs\":{\"type\":\"Object\",\"defaultValue\":\"dataetxizrfwxhflgdun\"},\"tmprvgrandz\":{\"type\":\"Array\",\"defaultValue\":\"dataksznf\"},\"lhsfddkhxvev\":{\"type\":\"Array\",\"defaultValue\":\"dataomlpczlqboomzgmr\"}},\"annotations\":[\"datanbwaxadxgnp\",\"datahtuhalpq\",\"datald\"],\"folder\":{\"name\":\"kexznpnytkqjarl\"},\"\":{\"rmzoujfgt\":\"datatgtzpca\"}}")
.toObject(NetezzaTableDataset.class);
- Assertions.assertEquals("zfyasyddqbws", model.description());
- Assertions.assertEquals("nwwumkbpg", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("zyxvta").type());
- Assertions.assertEquals("gfagijxmdbo", model.folder().name());
+ Assertions.assertEquals("toudodexwmvs", model.description());
+ Assertions.assertEquals("bsxehaxicjojxol", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("sdzmhwtsyppwf").type());
+ Assertions.assertEquals("kexznpnytkqjarl", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- NetezzaTableDataset model = new NetezzaTableDataset().withDescription("zfyasyddqbws")
- .withStructure("datawyyeomiflrvfe")
- .withSchema("datactshwfrhhasabvau")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("nwwumkbpg")
- .withParameters(mapOf("rpdgitenyuksli", "databwtpwbjlpfwuq", "amrplanch", "datampnxg", "z",
- "dataotmmxlmxejwyv", "sbeqieiuxhj", "datajwvtuekbbypqsm")))
- .withParameters(mapOf("zyxvta",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datalnjjhrgkjjpcpih"),
- "urdgc", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataatoidne")))
- .withAnnotations(Arrays.asList("datanaqve", "datagnpuelrnanbrpkoc", "dataxfbagegjtjltcki"))
- .withFolder(new DatasetFolder().withName("gfagijxmdbo"))
- .withTableName("datadvfjd")
- .withTable("dataephtoshqtuar")
- .withSchemaTypePropertiesSchema("datagujrcnxaeypyq");
+ NetezzaTableDataset model = new NetezzaTableDataset().withDescription("toudodexwmvs")
+ .withStructure("datajciexuwemtgtgeb")
+ .withSchema("datamcgsks")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bsxehaxicjojxol")
+ .withParameters(mapOf("mbglmnlbnatln", "datahgwakptb", "jk", "datahzzcdkxortdzzvhb", "dzccqtwsrbfbsd",
+ "datahophqwo", "vexrvnhhmfsnq", "dataicdzf")))
+ .withParameters(mapOf("sdzmhwtsyppwf",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datahlwvrs"),
+ "aypxsazbxs",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataetxizrfwxhflgdun"),
+ "tmprvgrandz", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataksznf"),
+ "lhsfddkhxvev",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataomlpczlqboomzgmr")))
+ .withAnnotations(Arrays.asList("datanbwaxadxgnp", "datahtuhalpq", "datald"))
+ .withFolder(new DatasetFolder().withName("kexznpnytkqjarl"))
+ .withTableName("datamblmfcleuov")
+ .withTable("datavspr")
+ .withSchemaTypePropertiesSchema("datajtez");
model = BinaryData.fromObject(model).toObject(NetezzaTableDataset.class);
- Assertions.assertEquals("zfyasyddqbws", model.description());
- Assertions.assertEquals("nwwumkbpg", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("zyxvta").type());
- Assertions.assertEquals("gfagijxmdbo", model.folder().name());
+ Assertions.assertEquals("toudodexwmvs", model.description());
+ Assertions.assertEquals("bsxehaxicjojxol", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("sdzmhwtsyppwf").type());
+ Assertions.assertEquals("kexznpnytkqjarl", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTypePropertiesTests.java
index 53011f6a9ca1..0fc9fe850e13 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NetezzaTableDatasetTypePropertiesTests.java
@@ -11,16 +11,15 @@ public final class NetezzaTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
NetezzaTableDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"datakrqdbsgkqy\",\"table\":\"dataotypcjxh\",\"schema\":\"datazlocjhzppdbr\"}")
+ .fromString("{\"tableName\":\"datauupcze\",\"table\":\"datanaidvssv\",\"schema\":\"dataoggkztzttjnknpb\"}")
.toObject(NetezzaTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- NetezzaTableDatasetTypeProperties model
- = new NetezzaTableDatasetTypeProperties().withTableName("datakrqdbsgkqy")
- .withTable("dataotypcjxh")
- .withSchema("datazlocjhzppdbr");
+ NetezzaTableDatasetTypeProperties model = new NetezzaTableDatasetTypeProperties().withTableName("datauupcze")
+ .withTable("datanaidvssv")
+ .withSchema("dataoggkztzttjnknpb");
model = BinaryData.fromObject(model).toObject(NetezzaTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NotebookParameterTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NotebookParameterTests.java
index aa3aedac13f0..c6995c25ed14 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NotebookParameterTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/NotebookParameterTests.java
@@ -12,16 +12,16 @@
public final class NotebookParameterTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- NotebookParameter model
- = BinaryData.fromString("{\"value\":\"datafekjvcl\",\"type\":\"float\"}").toObject(NotebookParameter.class);
- Assertions.assertEquals(NotebookParameterType.FLOAT, model.type());
+ NotebookParameter model = BinaryData.fromString("{\"value\":\"dataumccomjxx\",\"type\":\"string\"}")
+ .toObject(NotebookParameter.class);
+ Assertions.assertEquals(NotebookParameterType.STRING, model.type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
NotebookParameter model
- = new NotebookParameter().withValue("datafekjvcl").withType(NotebookParameterType.FLOAT);
+ = new NotebookParameter().withValue("dataumccomjxx").withType(NotebookParameterType.STRING);
model = BinaryData.fromObject(model).toObject(NotebookParameter.class);
- Assertions.assertEquals(NotebookParameterType.FLOAT, model.type());
+ Assertions.assertEquals(NotebookParameterType.STRING, model.type());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTests.java
index 8388f566eb49..e024fed25a84 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTests.java
@@ -19,34 +19,36 @@ public final class ODataResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ODataResourceDataset model = BinaryData.fromString(
- "{\"type\":\"ODataResource\",\"typeProperties\":{\"path\":\"datapeygkbzb\"},\"description\":\"asybxhqvovdpmht\",\"structure\":\"datavsqjs\",\"schema\":\"datajnqtaqg\",\"linkedServiceName\":{\"referenceName\":\"qbfkceincnrecjbi\",\"parameters\":{\"nszdosmjsq\":\"datavsfgdr\",\"vhgsulwvgseuf\":\"datavzvmxtcwghnda\",\"juzkilmc\":\"datagvf\"}},\"parameters\":{\"bybpaxhpzys\":{\"type\":\"Int\",\"defaultValue\":\"datazekypyovljlbzd\"},\"ahn\":{\"type\":\"Array\",\"defaultValue\":\"datanwbhanzgesfhshag\"}},\"annotations\":[\"databyfyvy\",\"datapmggqgagenvqbug\",\"datahcdvfoizorb\",\"dataoejzsaxzgkqwvdep\"],\"folder\":{\"name\":\"aphifkfrpm\"},\"\":{\"nfpgh\":\"databpebrmj\",\"tpkimskhnkkhbykr\":\"datab\"}}")
+ "{\"type\":\"ODataResource\",\"typeProperties\":{\"path\":\"dataepkwzzzkueruwcj\"},\"description\":\"ipvwkauj\",\"structure\":\"dataw\",\"schema\":\"dataox\",\"linkedServiceName\":{\"referenceName\":\"bwofxxdplr\",\"parameters\":{\"lbpxrhrfjenrazwe\":\"datakvgahcbtu\"}},\"parameters\":{\"jixy\":{\"type\":\"SecureString\",\"defaultValue\":\"datahqashtos\"},\"dwjtacfvvtd\":{\"type\":\"Object\",\"defaultValue\":\"datacigz\"}},\"annotations\":[\"datapzfomcsaugbr\",\"datafiwltkfysu\",\"datate\",\"datahkl\"],\"folder\":{\"name\":\"cvasyyh\"},\"\":{\"bmsrkix\":\"datak\",\"aqsy\":\"dataxxhwrlqo\"}}")
.toObject(ODataResourceDataset.class);
- Assertions.assertEquals("asybxhqvovdpmht", model.description());
- Assertions.assertEquals("qbfkceincnrecjbi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("bybpaxhpzys").type());
- Assertions.assertEquals("aphifkfrpm", model.folder().name());
+ Assertions.assertEquals("ipvwkauj", model.description());
+ Assertions.assertEquals("bwofxxdplr", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("jixy").type());
+ Assertions.assertEquals("cvasyyh", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ODataResourceDataset model = new ODataResourceDataset().withDescription("asybxhqvovdpmht")
- .withStructure("datavsqjs")
- .withSchema("datajnqtaqg")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qbfkceincnrecjbi")
+ ODataResourceDataset model
+ = new ODataResourceDataset().withDescription("ipvwkauj")
+ .withStructure("dataw")
+ .withSchema("dataox")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bwofxxdplr")
+ .withParameters(mapOf("lbpxrhrfjenrazwe", "datakvgahcbtu")))
.withParameters(
- mapOf("nszdosmjsq", "datavsfgdr", "vhgsulwvgseuf", "datavzvmxtcwghnda", "juzkilmc", "datagvf")))
- .withParameters(mapOf("bybpaxhpzys",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datazekypyovljlbzd"), "ahn",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanwbhanzgesfhshag")))
- .withAnnotations(
- Arrays.asList("databyfyvy", "datapmggqgagenvqbug", "datahcdvfoizorb", "dataoejzsaxzgkqwvdep"))
- .withFolder(new DatasetFolder().withName("aphifkfrpm"))
- .withPath("datapeygkbzb");
+ mapOf("jixy",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datahqashtos"),
+ "dwjtacfvvtd",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datacigz")))
+ .withAnnotations(Arrays.asList("datapzfomcsaugbr", "datafiwltkfysu", "datate", "datahkl"))
+ .withFolder(new DatasetFolder().withName("cvasyyh"))
+ .withPath("dataepkwzzzkueruwcj");
model = BinaryData.fromObject(model).toObject(ODataResourceDataset.class);
- Assertions.assertEquals("asybxhqvovdpmht", model.description());
- Assertions.assertEquals("qbfkceincnrecjbi", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("bybpaxhpzys").type());
- Assertions.assertEquals("aphifkfrpm", model.folder().name());
+ Assertions.assertEquals("ipvwkauj", model.description());
+ Assertions.assertEquals("bwofxxdplr", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("jixy").type());
+ Assertions.assertEquals("cvasyyh", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTypePropertiesTests.java
index 254a51a4314d..2413c45ec4de 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataResourceDatasetTypePropertiesTests.java
@@ -10,14 +10,13 @@
public final class ODataResourceDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- ODataResourceDatasetTypeProperties model = BinaryData.fromString("{\"path\":\"datahrcmelycpgokuth\"}")
- .toObject(ODataResourceDatasetTypeProperties.class);
+ ODataResourceDatasetTypeProperties model
+ = BinaryData.fromString("{\"path\":\"datapzzbrwn\"}").toObject(ODataResourceDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ODataResourceDatasetTypeProperties model
- = new ODataResourceDatasetTypeProperties().withPath("datahrcmelycpgokuth");
+ ODataResourceDatasetTypeProperties model = new ODataResourceDatasetTypeProperties().withPath("datapzzbrwn");
model = BinaryData.fromObject(model).toObject(ODataResourceDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataSourceTests.java
index ff4ed70d2a14..5a042b9c169b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ODataSourceTests.java
@@ -11,19 +11,19 @@ public final class ODataSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ODataSource model = BinaryData.fromString(
- "{\"type\":\"ODataSource\",\"query\":\"datadgem\",\"httpRequestTimeout\":\"datayddzjtxlvgsl\",\"additionalColumns\":\"datalys\",\"sourceRetryCount\":\"datav\",\"sourceRetryWait\":\"dataak\",\"maxConcurrentConnections\":\"datapaexllt\",\"disableMetricsCollection\":\"datakkaei\",\"\":{\"vsrtqltawjkra\":\"datardns\"}}")
+ "{\"type\":\"ODataSource\",\"query\":\"datahuboqozx\",\"httpRequestTimeout\":\"dataxamxi\",\"additionalColumns\":\"datar\",\"sourceRetryCount\":\"datakglynbqpeoj\",\"sourceRetryWait\":\"databoggw\",\"maxConcurrentConnections\":\"datahtnywgtsodnxeir\",\"disableMetricsCollection\":\"datawjimcfrhtzgduvoa\",\"\":{\"zyqbggxcyram\":\"datacalptfp\",\"nyurxlpuwxsl\":\"datazuaxtbr\",\"bj\":\"dataqlgxxbnrurtn\",\"fbmdemohls\":\"dataysupck\"}}")
.toObject(ODataSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ODataSource model = new ODataSource().withSourceRetryCount("datav")
- .withSourceRetryWait("dataak")
- .withMaxConcurrentConnections("datapaexllt")
- .withDisableMetricsCollection("datakkaei")
- .withQuery("datadgem")
- .withHttpRequestTimeout("datayddzjtxlvgsl")
- .withAdditionalColumns("datalys");
+ ODataSource model = new ODataSource().withSourceRetryCount("datakglynbqpeoj")
+ .withSourceRetryWait("databoggw")
+ .withMaxConcurrentConnections("datahtnywgtsodnxeir")
+ .withDisableMetricsCollection("datawjimcfrhtzgduvoa")
+ .withQuery("datahuboqozx")
+ .withHttpRequestTimeout("dataxamxi")
+ .withAdditionalColumns("datar");
model = BinaryData.fromObject(model).toObject(ODataSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSinkTests.java
index 07d052e8dfa2..1340b3723857 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSinkTests.java
@@ -11,19 +11,19 @@ public final class OdbcSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OdbcSink model = BinaryData.fromString(
- "{\"type\":\"OdbcSink\",\"preCopyScript\":\"datadbe\",\"writeBatchSize\":\"datajhfszmxposmqsc\",\"writeBatchTimeout\":\"datauldkpdle\",\"sinkRetryCount\":\"dataljujpsubxggknmvk\",\"sinkRetryWait\":\"dataqoqyrcpsjeazz\",\"maxConcurrentConnections\":\"datacsbkmaluchbfrtaj\",\"disableMetricsCollection\":\"dataddyqdxpnzpuk\",\"\":{\"yxauw\":\"dataggitxsyufexivh\",\"xazywijb\":\"datakqofrkfccqjenzl\",\"flxdwliitaieledm\":\"dataqaeyjozbd\"}}")
+ "{\"type\":\"OdbcSink\",\"preCopyScript\":\"datauaqtqnqm\",\"writeBatchSize\":\"dataptzgomuju\",\"writeBatchTimeout\":\"datankuyombkgkyobu\",\"sinkRetryCount\":\"dataprvokodrpyxkzx\",\"sinkRetryWait\":\"datamoycufkxygxoubek\",\"maxConcurrentConnections\":\"datadxgtgcfk\",\"disableMetricsCollection\":\"datae\",\"\":{\"fpqebbqetx\":\"datahtlk\"}}")
.toObject(OdbcSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OdbcSink model = new OdbcSink().withWriteBatchSize("datajhfszmxposmqsc")
- .withWriteBatchTimeout("datauldkpdle")
- .withSinkRetryCount("dataljujpsubxggknmvk")
- .withSinkRetryWait("dataqoqyrcpsjeazz")
- .withMaxConcurrentConnections("datacsbkmaluchbfrtaj")
- .withDisableMetricsCollection("dataddyqdxpnzpuk")
- .withPreCopyScript("datadbe");
+ OdbcSink model = new OdbcSink().withWriteBatchSize("dataptzgomuju")
+ .withWriteBatchTimeout("datankuyombkgkyobu")
+ .withSinkRetryCount("dataprvokodrpyxkzx")
+ .withSinkRetryWait("datamoycufkxygxoubek")
+ .withMaxConcurrentConnections("datadxgtgcfk")
+ .withDisableMetricsCollection("datae")
+ .withPreCopyScript("datauaqtqnqm");
model = BinaryData.fromObject(model).toObject(OdbcSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSourceTests.java
index ff0a850d7240..f52a9d6b24a9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcSourceTests.java
@@ -11,19 +11,19 @@ public final class OdbcSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OdbcSource model = BinaryData.fromString(
- "{\"type\":\"OdbcSource\",\"query\":\"dataejyavkyjvctq\",\"queryTimeout\":\"datacz\",\"additionalColumns\":\"datapaeyklxsvcbr\",\"sourceRetryCount\":\"datalt\",\"sourceRetryWait\":\"datamdsngoaofmrph\",\"maxConcurrentConnections\":\"datas\",\"disableMetricsCollection\":\"dataunkcgdnhacex\",\"\":{\"ffxan\":\"datamrrjooepfbas\",\"yp\":\"datagntjmnlpklrjd\",\"gnjatjbldgik\":\"datakvi\"}}")
+ "{\"type\":\"OdbcSource\",\"query\":\"databnekhjzbfb\",\"queryTimeout\":\"dataeqkuozarr\",\"additionalColumns\":\"datapyzryjb\",\"sourceRetryCount\":\"databcvoyqnrjdrc\",\"sourceRetryWait\":\"datarvzewogh\",\"maxConcurrentConnections\":\"datazxkjqecj\",\"disableMetricsCollection\":\"dataromeawthycbigpi\",\"\":{\"lawakhe\":\"dataxhzjnparsulmu\",\"talo\":\"dataxxqgoavzycxpza\",\"r\":\"datamftmxwtwzs\",\"qhfvouyqzhoik\":\"datarf\"}}")
.toObject(OdbcSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OdbcSource model = new OdbcSource().withSourceRetryCount("datalt")
- .withSourceRetryWait("datamdsngoaofmrph")
- .withMaxConcurrentConnections("datas")
- .withDisableMetricsCollection("dataunkcgdnhacex")
- .withQueryTimeout("datacz")
- .withAdditionalColumns("datapaeyklxsvcbr")
- .withQuery("dataejyavkyjvctq");
+ OdbcSource model = new OdbcSource().withSourceRetryCount("databcvoyqnrjdrc")
+ .withSourceRetryWait("datarvzewogh")
+ .withMaxConcurrentConnections("datazxkjqecj")
+ .withDisableMetricsCollection("dataromeawthycbigpi")
+ .withQueryTimeout("dataeqkuozarr")
+ .withAdditionalColumns("datapyzryjb")
+ .withQuery("databnekhjzbfb");
model = BinaryData.fromObject(model).toObject(OdbcSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTests.java
index bb889f83237d..cdf63329b486 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTests.java
@@ -19,32 +19,31 @@ public final class OdbcTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OdbcTableDataset model = BinaryData.fromString(
- "{\"type\":\"OdbcTable\",\"typeProperties\":{\"tableName\":\"dataizp\"},\"description\":\"fxzspfyvslazippl\",\"structure\":\"datatdumjtycildrzn\",\"schema\":\"dataxozqthkwxfugfziz\",\"linkedServiceName\":{\"referenceName\":\"xduyjnqzbrqcakm\",\"parameters\":{\"nsbqoitwhmuc\":\"dataviyjuca\",\"xy\":\"dataiuh\",\"ycudus\":\"dataehyklelyqdvpqfbx\",\"vfopkyl\":\"datamtxqlefnohey\"}},\"parameters\":{\"w\":{\"type\":\"SecureString\",\"defaultValue\":\"datanj\"}},\"annotations\":[\"datafwtwrsvevc\",\"datae\",\"dataswxhqhgkhtbzv\"],\"folder\":{\"name\":\"evvjncpmyhtxg\"},\"\":{\"bcyjrtalqee\":\"dataghcmixmlwkfe\",\"tomsgoihlqwbywaa\":\"dataudfyimooaez\"}}")
+ "{\"type\":\"OdbcTable\",\"typeProperties\":{\"tableName\":\"databfb\"},\"description\":\"ow\",\"structure\":\"dataljdkxhmewyaolc\",\"schema\":\"datax\",\"linkedServiceName\":{\"referenceName\":\"rdpuyytbpkrp\",\"parameters\":{\"nefnoafp\":\"dataetpo\"}},\"parameters\":{\"ufcmuajwblxp\":{\"type\":\"String\",\"defaultValue\":\"datayrxowv\"}},\"annotations\":[\"datazfrfaw\",\"datannsvrfajynihti\",\"dataufgzq\"],\"folder\":{\"name\":\"uctblfehbgcgyoh\"},\"\":{\"xonebldxagmd\":\"dataeqljxdumhy\",\"xjsjqu\":\"datajwcngk\",\"crzhnsbylg\":\"dataohufzdtsrpjuvgz\",\"nbfulv\":\"datagbhuqczou\"}}")
.toObject(OdbcTableDataset.class);
- Assertions.assertEquals("fxzspfyvslazippl", model.description());
- Assertions.assertEquals("xduyjnqzbrqcakm", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("w").type());
- Assertions.assertEquals("evvjncpmyhtxg", model.folder().name());
+ Assertions.assertEquals("ow", model.description());
+ Assertions.assertEquals("rdpuyytbpkrp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("ufcmuajwblxp").type());
+ Assertions.assertEquals("uctblfehbgcgyoh", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OdbcTableDataset model = new OdbcTableDataset().withDescription("fxzspfyvslazippl")
- .withStructure("datatdumjtycildrzn")
- .withSchema("dataxozqthkwxfugfziz")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("xduyjnqzbrqcakm")
- .withParameters(mapOf("nsbqoitwhmuc", "dataviyjuca", "xy", "dataiuh", "ycudus", "dataehyklelyqdvpqfbx",
- "vfopkyl", "datamtxqlefnohey")))
- .withParameters(mapOf("w",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datanj")))
- .withAnnotations(Arrays.asList("datafwtwrsvevc", "datae", "dataswxhqhgkhtbzv"))
- .withFolder(new DatasetFolder().withName("evvjncpmyhtxg"))
- .withTableName("dataizp");
+ OdbcTableDataset model = new OdbcTableDataset().withDescription("ow")
+ .withStructure("dataljdkxhmewyaolc")
+ .withSchema("datax")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rdpuyytbpkrp")
+ .withParameters(mapOf("nefnoafp", "dataetpo")))
+ .withParameters(mapOf("ufcmuajwblxp",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datayrxowv")))
+ .withAnnotations(Arrays.asList("datazfrfaw", "datannsvrfajynihti", "dataufgzq"))
+ .withFolder(new DatasetFolder().withName("uctblfehbgcgyoh"))
+ .withTableName("databfb");
model = BinaryData.fromObject(model).toObject(OdbcTableDataset.class);
- Assertions.assertEquals("fxzspfyvslazippl", model.description());
- Assertions.assertEquals("xduyjnqzbrqcakm", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("w").type());
- Assertions.assertEquals("evvjncpmyhtxg", model.folder().name());
+ Assertions.assertEquals("ow", model.description());
+ Assertions.assertEquals("rdpuyytbpkrp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("ufcmuajwblxp").type());
+ Assertions.assertEquals("uctblfehbgcgyoh", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTypePropertiesTests.java
index 20bcabc6baf5..468732663645 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OdbcTableDatasetTypePropertiesTests.java
@@ -10,13 +10,13 @@
public final class OdbcTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- OdbcTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"dataaeeekfztvna\"}")
+ OdbcTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"dataglxoqwbztilqb\"}")
.toObject(OdbcTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OdbcTableDatasetTypeProperties model = new OdbcTableDatasetTypeProperties().withTableName("dataaeeekfztvna");
+ OdbcTableDatasetTypeProperties model = new OdbcTableDatasetTypeProperties().withTableName("dataglxoqwbztilqb");
model = BinaryData.fromObject(model).toObject(OdbcTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTests.java
index 235ba380e256..b4ade61d499a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTests.java
@@ -19,37 +19,37 @@ public final class Office365DatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
Office365Dataset model = BinaryData.fromString(
- "{\"type\":\"Office365Table\",\"typeProperties\":{\"tableName\":\"datauynf\",\"predicate\":\"datayvnhiysdhor\"},\"description\":\"lhr\",\"structure\":\"datakiwlwkfflaqwmwq\",\"schema\":\"datauf\",\"linkedServiceName\":{\"referenceName\":\"tea\",\"parameters\":{\"njtqbg\":\"datagefzj\",\"dbtqyh\":\"datasibthnvxwtdqtcb\"}},\"parameters\":{\"voawhgj\":{\"type\":\"Object\",\"defaultValue\":\"dataaujqgbbjv\"},\"he\":{\"type\":\"Bool\",\"defaultValue\":\"datacsloygsabdg\"},\"uyxtrvfdbqs\":{\"type\":\"Float\",\"defaultValue\":\"datasdunrkzvzuatqhg\"},\"avdhpiw\":{\"type\":\"String\",\"defaultValue\":\"datajbvitptpvsf\"}},\"annotations\":[\"datawkgjwb\",\"datafdwfbwxy\",\"datadqtmggcpdrmeg\",\"datajrzctwymz\"],\"folder\":{\"name\":\"qkkge\"},\"\":{\"lcaxsqcomjiqi\":\"dataphgliupqscoobk\",\"ziizmeqmdu\":\"datancevxxkdevpxi\"}}")
+ "{\"type\":\"Office365Table\",\"typeProperties\":{\"tableName\":\"datactsmwpgweoqhbjq\",\"predicate\":\"datafblerufol\"},\"description\":\"shjucihbymjjvt\",\"structure\":\"dataerx\",\"schema\":\"dataeazr\",\"linkedServiceName\":{\"referenceName\":\"helhbimyi\",\"parameters\":{\"cthtpq\":\"dataa\",\"zkdiuvflgzhcw\":\"datafzdos\",\"g\":\"datagwahcrxo\"}},\"parameters\":{\"pmhz\":{\"type\":\"Float\",\"defaultValue\":\"datapccxziv\"},\"tujqzvhnjvpmxnh\":{\"type\":\"Float\",\"defaultValue\":\"datahkvnnj\"},\"lgxyf\":{\"type\":\"Array\",\"defaultValue\":\"datastqlfxolrwv\"},\"lzyyopoaytw\":{\"type\":\"SecureString\",\"defaultValue\":\"dataequ\"}},\"annotations\":[\"dataqubotbvuf\",\"datakwjiemimdtnpowe\"],\"folder\":{\"name\":\"kreeeddd\"},\"\":{\"igeeuwbr\":\"datafquulpclhs\",\"netdqw\":\"dataqyxfed\"}}")
.toObject(Office365Dataset.class);
- Assertions.assertEquals("lhr", model.description());
- Assertions.assertEquals("tea", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("voawhgj").type());
- Assertions.assertEquals("qkkge", model.folder().name());
+ Assertions.assertEquals("shjucihbymjjvt", model.description());
+ Assertions.assertEquals("helhbimyi", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("pmhz").type());
+ Assertions.assertEquals("kreeeddd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- Office365Dataset model = new Office365Dataset().withDescription("lhr")
- .withStructure("datakiwlwkfflaqwmwq")
- .withSchema("datauf")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tea")
- .withParameters(mapOf("njtqbg", "datagefzj", "dbtqyh", "datasibthnvxwtdqtcb")))
- .withParameters(mapOf("voawhgj",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataaujqgbbjv"), "he",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datacsloygsabdg"),
- "uyxtrvfdbqs",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datasdunrkzvzuatqhg"),
- "avdhpiw",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datajbvitptpvsf")))
- .withAnnotations(Arrays.asList("datawkgjwb", "datafdwfbwxy", "datadqtmggcpdrmeg", "datajrzctwymz"))
- .withFolder(new DatasetFolder().withName("qkkge"))
- .withTableName("datauynf")
- .withPredicate("datayvnhiysdhor");
+ Office365Dataset model = new Office365Dataset().withDescription("shjucihbymjjvt")
+ .withStructure("dataerx")
+ .withSchema("dataeazr")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("helhbimyi")
+ .withParameters(mapOf("cthtpq", "dataa", "zkdiuvflgzhcw", "datafzdos", "g", "datagwahcrxo")))
+ .withParameters(mapOf("pmhz",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datapccxziv"),
+ "tujqzvhnjvpmxnh",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datahkvnnj"), "lgxyf",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datastqlfxolrwv"),
+ "lzyyopoaytw",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataequ")))
+ .withAnnotations(Arrays.asList("dataqubotbvuf", "datakwjiemimdtnpowe"))
+ .withFolder(new DatasetFolder().withName("kreeeddd"))
+ .withTableName("datactsmwpgweoqhbjq")
+ .withPredicate("datafblerufol");
model = BinaryData.fromObject(model).toObject(Office365Dataset.class);
- Assertions.assertEquals("lhr", model.description());
- Assertions.assertEquals("tea", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("voawhgj").type());
- Assertions.assertEquals("qkkge", model.folder().name());
+ Assertions.assertEquals("shjucihbymjjvt", model.description());
+ Assertions.assertEquals("helhbimyi", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("pmhz").type());
+ Assertions.assertEquals("kreeeddd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTypePropertiesTests.java
index 754fe2c32e72..757ef6e4bf24 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365DatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class Office365DatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
Office365DatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datatv\",\"predicate\":\"dataqxxpqhmlqi\"}")
+ = BinaryData.fromString("{\"tableName\":\"datanxoqgv\",\"predicate\":\"datapgg\"}")
.toObject(Office365DatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
Office365DatasetTypeProperties model
- = new Office365DatasetTypeProperties().withTableName("datatv").withPredicate("dataqxxpqhmlqi");
+ = new Office365DatasetTypeProperties().withTableName("datanxoqgv").withPredicate("datapgg");
model = BinaryData.fromObject(model).toObject(Office365DatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365SourceTests.java
index 13b5a1be525b..bccf15af2d71 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/Office365SourceTests.java
@@ -11,22 +11,22 @@ public final class Office365SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
Office365Source model = BinaryData.fromString(
- "{\"type\":\"Office365Source\",\"allowedGroups\":\"datavddfmflwfxdkpwd\",\"userScopeFilterUri\":\"datayg\",\"dateFilterColumn\":\"dataugcht\",\"startTime\":\"datai\",\"endTime\":\"datadlrxbsuftpvgmqzi\",\"outputColumns\":\"datauvmlltas\",\"sourceRetryCount\":\"dataqsf\",\"sourceRetryWait\":\"datae\",\"maxConcurrentConnections\":\"dataveg\",\"disableMetricsCollection\":\"databmyvgmbirvv\",\"\":{\"tu\":\"dataqxisav\",\"ridagwuvcdymoq\":\"datawzvlhi\",\"h\":\"datacjkrynziud\"}}")
+ "{\"type\":\"Office365Source\",\"allowedGroups\":\"datasdeequovanag\",\"userScopeFilterUri\":\"dataacsfbmb\",\"dateFilterColumn\":\"dataefqku\",\"startTime\":\"datayumoamqxwluslxyt\",\"endTime\":\"databjledjxblobknfpd\",\"outputColumns\":\"datahzgj\",\"sourceRetryCount\":\"dataomctbgoccypxsrh\",\"sourceRetryWait\":\"datalbnuflfzawk\",\"maxConcurrentConnections\":\"datae\",\"disableMetricsCollection\":\"databpyo\",\"\":{\"y\":\"datajpclboiojpjnhw\"}}")
.toObject(Office365Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- Office365Source model = new Office365Source().withSourceRetryCount("dataqsf")
- .withSourceRetryWait("datae")
- .withMaxConcurrentConnections("dataveg")
- .withDisableMetricsCollection("databmyvgmbirvv")
- .withAllowedGroups("datavddfmflwfxdkpwd")
- .withUserScopeFilterUri("datayg")
- .withDateFilterColumn("dataugcht")
- .withStartTime("datai")
- .withEndTime("datadlrxbsuftpvgmqzi")
- .withOutputColumns("datauvmlltas");
+ Office365Source model = new Office365Source().withSourceRetryCount("dataomctbgoccypxsrh")
+ .withSourceRetryWait("datalbnuflfzawk")
+ .withMaxConcurrentConnections("datae")
+ .withDisableMetricsCollection("databpyo")
+ .withAllowedGroups("datasdeequovanag")
+ .withUserScopeFilterUri("dataacsfbmb")
+ .withDateFilterColumn("dataefqku")
+ .withStartTime("datayumoamqxwluslxyt")
+ .withEndTime("databjledjxblobknfpd")
+ .withOutputColumns("datahzgj");
model = BinaryData.fromObject(model).toObject(Office365Source.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OperationsListMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OperationsListMockTests.java
index e61d0f129e0f..28faa5170c9f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OperationsListMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OperationsListMockTests.java
@@ -22,7 +22,7 @@ public final class OperationsListMockTests {
@Test
public void testList() throws Exception {
String responseStr
- = "{\"value\":[{\"name\":\"lshwaadczwmnfavl\",\"origin\":\"sklsakkihxpofv\",\"display\":{\"description\":\"eaxor\",\"provider\":\"zbdvawbtgvqtegk\",\"resource\":\"ecl\",\"operation\":\"scdoqocdrjguhsjl\"},\"properties\":{\"serviceSpecification\":{\"logSpecifications\":[{\"name\":\"whbsejuuboy\",\"displayName\":\"qyjtollugz\",\"blobDuration\":\"zikk\"},{\"name\":\"bdaudsvdb\",\"displayName\":\"lmutwm\",\"blobDuration\":\"fbsz\"}],\"metricSpecifications\":[{\"name\":\"s\",\"displayName\":\"rdmbebxmkwokl\",\"displayDescription\":\"cenngutitjwvv\",\"unit\":\"pdshkbfweezzr\",\"aggregationType\":\"ytq\",\"enableRegionalMdmAccount\":\"bxgofiphl\",\"sourceMdmAccount\":\"zdphidhkigslczk\",\"sourceMdmNamespace\":\"bz\",\"availabilities\":[{},{}],\"dimensions\":[{}]}]}}}]}";
+ = "{\"value\":[{\"name\":\"b\",\"origin\":\"eiakwdtuwbrw\",\"display\":{\"description\":\"tyuywzccumkliygr\",\"provider\":\"olvitbtloxr\",\"resource\":\"tzvrgoxpayjs\",\"operation\":\"rfqstbfuqmlnefvb\"},\"properties\":{\"serviceSpecification\":{\"logSpecifications\":[{\"name\":\"fshntykenmjznjq\",\"displayName\":\"yaaevrkxyjsuapp\",\"blobDuration\":\"ujiguusbwmsy\"},{\"name\":\"bjtzd\",\"displayName\":\"twkq\",\"blobDuration\":\"lfovmc\"}],\"metricSpecifications\":[{\"name\":\"ofqdvqvjfszvece\",\"displayName\":\"ptez\",\"displayDescription\":\"r\",\"unit\":\"urcjgkau\",\"aggregationType\":\"brdibdbkgxqs\",\"enableRegionalMdmAccount\":\"epduy\",\"sourceMdmAccount\":\"vjxarddb\",\"sourceMdmNamespace\":\"yaylt\",\"availabilities\":[{}],\"dimensions\":[{},{},{}]}]}}}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -33,33 +33,33 @@ public void testList() throws Exception {
PagedIterable response = manager.operations().list(com.azure.core.util.Context.NONE);
- Assertions.assertEquals("lshwaadczwmnfavl", response.iterator().next().name());
- Assertions.assertEquals("sklsakkihxpofv", response.iterator().next().origin());
- Assertions.assertEquals("eaxor", response.iterator().next().display().description());
- Assertions.assertEquals("zbdvawbtgvqtegk", response.iterator().next().display().provider());
- Assertions.assertEquals("ecl", response.iterator().next().display().resource());
- Assertions.assertEquals("scdoqocdrjguhsjl", response.iterator().next().display().operation());
- Assertions.assertEquals("whbsejuuboy",
+ Assertions.assertEquals("b", response.iterator().next().name());
+ Assertions.assertEquals("eiakwdtuwbrw", response.iterator().next().origin());
+ Assertions.assertEquals("tyuywzccumkliygr", response.iterator().next().display().description());
+ Assertions.assertEquals("olvitbtloxr", response.iterator().next().display().provider());
+ Assertions.assertEquals("tzvrgoxpayjs", response.iterator().next().display().resource());
+ Assertions.assertEquals("rfqstbfuqmlnefvb", response.iterator().next().display().operation());
+ Assertions.assertEquals("fshntykenmjznjq",
response.iterator().next().serviceSpecification().logSpecifications().get(0).name());
- Assertions.assertEquals("qyjtollugz",
+ Assertions.assertEquals("yaaevrkxyjsuapp",
response.iterator().next().serviceSpecification().logSpecifications().get(0).displayName());
- Assertions.assertEquals("zikk",
+ Assertions.assertEquals("ujiguusbwmsy",
response.iterator().next().serviceSpecification().logSpecifications().get(0).blobDuration());
- Assertions.assertEquals("s",
+ Assertions.assertEquals("ofqdvqvjfszvece",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).name());
- Assertions.assertEquals("rdmbebxmkwokl",
+ Assertions.assertEquals("ptez",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).displayName());
- Assertions.assertEquals("cenngutitjwvv",
+ Assertions.assertEquals("r",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).displayDescription());
- Assertions.assertEquals("pdshkbfweezzr",
+ Assertions.assertEquals("urcjgkau",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).unit());
- Assertions.assertEquals("ytq",
+ Assertions.assertEquals("brdibdbkgxqs",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).aggregationType());
- Assertions.assertEquals("bxgofiphl",
+ Assertions.assertEquals("epduy",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).enableRegionalMdmAccount());
- Assertions.assertEquals("zdphidhkigslczk",
+ Assertions.assertEquals("vjxarddb",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).sourceMdmAccount());
- Assertions.assertEquals("bz",
+ Assertions.assertEquals("yaylt",
response.iterator().next().serviceSpecification().metricSpecifications().get(0).sourceMdmNamespace());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleCloudStorageReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleCloudStorageReadSettingsTests.java
index e75da383602b..085105e3832c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleCloudStorageReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleCloudStorageReadSettingsTests.java
@@ -11,25 +11,25 @@ public final class OracleCloudStorageReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OracleCloudStorageReadSettings model = BinaryData.fromString(
- "{\"type\":\"OracleCloudStorageReadSettings\",\"recursive\":\"dataycpotmaosongt\",\"wildcardFolderPath\":\"datavhsqvubwwqgiyu\",\"wildcardFileName\":\"datarvwjxmwal\",\"prefix\":\"datajtnsnbpiuvqho\",\"fileListPath\":\"datamortr\",\"enablePartitionDiscovery\":\"datapbsungnjkkmkz\",\"partitionRootPath\":\"datajucgbgz\",\"deleteFilesAfterCompletion\":\"datardiiwhmrhzqqvpjy\",\"modifiedDatetimeStart\":\"datamaqe\",\"modifiedDatetimeEnd\":\"datajpua\",\"maxConcurrentConnections\":\"dataqupdcsvzugi\",\"disableMetricsCollection\":\"datahgqlvlbjzsc\",\"\":{\"iwxlylxfpvoylf\":\"datanqbkpobjufksddxk\",\"ime\":\"datalsrguecbthauivg\",\"uvckpdpdcnrjqs\":\"dataedqgyrvulz\",\"seti\":\"dataikqdqiybqtlvofj\"}}")
+ "{\"type\":\"OracleCloudStorageReadSettings\",\"recursive\":\"datarviynlslgxifkds\",\"wildcardFolderPath\":\"dataqwkddgep\",\"wildcardFileName\":\"dataambzfxgshaq\",\"prefix\":\"dataeqfniag\",\"fileListPath\":\"datayxsoxqa\",\"enablePartitionDiscovery\":\"datatunll\",\"partitionRootPath\":\"datat\",\"deleteFilesAfterCompletion\":\"dataguuhylzbdimtdohj\",\"modifiedDatetimeStart\":\"dataq\",\"modifiedDatetimeEnd\":\"datauwcilxznxhbttkk\",\"maxConcurrentConnections\":\"dataxjxueilixzjvkqj\",\"disableMetricsCollection\":\"datablhcmxx\",\"\":{\"kmsfsquxxqc\":\"datakxclj\",\"csmrtepsybdgtf\":\"datamnchvkjwriva\",\"bpbpqelmsz\":\"datazysfjdco\",\"drumududwecdsyb\":\"databtneltnbyvbg\"}}")
.toObject(OracleCloudStorageReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
OracleCloudStorageReadSettings model
- = new OracleCloudStorageReadSettings().withMaxConcurrentConnections("dataqupdcsvzugi")
- .withDisableMetricsCollection("datahgqlvlbjzsc")
- .withRecursive("dataycpotmaosongt")
- .withWildcardFolderPath("datavhsqvubwwqgiyu")
- .withWildcardFileName("datarvwjxmwal")
- .withPrefix("datajtnsnbpiuvqho")
- .withFileListPath("datamortr")
- .withEnablePartitionDiscovery("datapbsungnjkkmkz")
- .withPartitionRootPath("datajucgbgz")
- .withDeleteFilesAfterCompletion("datardiiwhmrhzqqvpjy")
- .withModifiedDatetimeStart("datamaqe")
- .withModifiedDatetimeEnd("datajpua");
+ = new OracleCloudStorageReadSettings().withMaxConcurrentConnections("dataxjxueilixzjvkqj")
+ .withDisableMetricsCollection("datablhcmxx")
+ .withRecursive("datarviynlslgxifkds")
+ .withWildcardFolderPath("dataqwkddgep")
+ .withWildcardFileName("dataambzfxgshaq")
+ .withPrefix("dataeqfniag")
+ .withFileListPath("datayxsoxqa")
+ .withEnablePartitionDiscovery("datatunll")
+ .withPartitionRootPath("datat")
+ .withDeleteFilesAfterCompletion("dataguuhylzbdimtdohj")
+ .withModifiedDatetimeStart("dataq")
+ .withModifiedDatetimeEnd("datauwcilxznxhbttkk");
model = BinaryData.fromObject(model).toObject(OracleCloudStorageReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OraclePartitionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OraclePartitionSettingsTests.java
index 4d5d31a18808..f6f80849d668 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OraclePartitionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OraclePartitionSettingsTests.java
@@ -11,16 +11,16 @@ public final class OraclePartitionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OraclePartitionSettings model = BinaryData.fromString(
- "{\"partitionNames\":\"dataihgk\",\"partitionColumnName\":\"datawzuo\",\"partitionUpperBound\":\"datayxlrd\",\"partitionLowerBound\":\"dataudfar\"}")
+ "{\"partitionNames\":\"datast\",\"partitionColumnName\":\"datafbyfjslehgee\",\"partitionUpperBound\":\"datasoj\",\"partitionLowerBound\":\"dataarliig\"}")
.toObject(OraclePartitionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OraclePartitionSettings model = new OraclePartitionSettings().withPartitionNames("dataihgk")
- .withPartitionColumnName("datawzuo")
- .withPartitionUpperBound("datayxlrd")
- .withPartitionLowerBound("dataudfar");
+ OraclePartitionSettings model = new OraclePartitionSettings().withPartitionNames("datast")
+ .withPartitionColumnName("datafbyfjslehgee")
+ .withPartitionUpperBound("datasoj")
+ .withPartitionLowerBound("dataarliig");
model = BinaryData.fromObject(model).toObject(OraclePartitionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudObjectDatasetTests.java
index 6c2b4d157ea3..49996a3a61e0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudObjectDatasetTests.java
@@ -19,34 +19,36 @@ public final class OracleServiceCloudObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OracleServiceCloudObjectDataset model = BinaryData.fromString(
- "{\"type\":\"OracleServiceCloudObject\",\"typeProperties\":{\"tableName\":\"datakkv\"},\"description\":\"aehjjirvjq\",\"structure\":\"datavqmdmrac\",\"schema\":\"dataffdralihhs\",\"linkedServiceName\":{\"referenceName\":\"cygyzhcv\",\"parameters\":{\"dxrmyzvti\":\"datayrjl\"}},\"parameters\":{\"xoyjyhutwedigiv\":{\"type\":\"Float\",\"defaultValue\":\"datarubx\"},\"mcaxbqpmfhji\":{\"type\":\"Array\",\"defaultValue\":\"dataccxfnatn\"},\"lzvrchmy\":{\"type\":\"Array\",\"defaultValue\":\"datanbdqitghnm\"},\"h\":{\"type\":\"String\",\"defaultValue\":\"datarmwy\"}},\"annotations\":[\"dataplgqqqgrbr\",\"datahvipgt\"],\"folder\":{\"name\":\"aoylwhfm\"},\"\":{\"gypjixdmobadydw\":\"dataea\",\"wdvclsx\":\"datae\",\"xr\":\"dataqdchnzib\"}}")
+ "{\"type\":\"OracleServiceCloudObject\",\"typeProperties\":{\"tableName\":\"datasyajmmczupd\"},\"description\":\"grufsdbkuxkdi\",\"structure\":\"datagsivxwkscwbsh\",\"schema\":\"datahvlms\",\"linkedServiceName\":{\"referenceName\":\"eylaulpuexy\",\"parameters\":{\"lspgnndefyhsb\":\"dataztyecxd\",\"ltaprq\":\"datahwlvsvs\",\"cuhbgftfvqukkmvz\":\"datafkmvzrkpmonxdw\",\"dqrjylwqqsemjhh\":\"dataneg\"}},\"parameters\":{\"tdpfz\":{\"type\":\"String\",\"defaultValue\":\"dataehztbejrdzwy\"},\"mjkykqflkm\":{\"type\":\"Bool\",\"defaultValue\":\"dataifnjwj\"},\"hc\":{\"type\":\"Bool\",\"defaultValue\":\"dataxmysmkbndnrihpja\"},\"ig\":{\"type\":\"Object\",\"defaultValue\":\"datajn\"}},\"annotations\":[\"datalkrnpsbnmrmhkip\"],\"folder\":{\"name\":\"dvdpfgwdxm\"},\"\":{\"unddvjlpbjszqj\":\"datalnpbiec\",\"ypbrzwi\":\"dataskjvaycxrwknsbg\",\"cebtpgvut\":\"datapzcyhk\"}}")
.toObject(OracleServiceCloudObjectDataset.class);
- Assertions.assertEquals("aehjjirvjq", model.description());
- Assertions.assertEquals("cygyzhcv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("xoyjyhutwedigiv").type());
- Assertions.assertEquals("aoylwhfm", model.folder().name());
+ Assertions.assertEquals("grufsdbkuxkdi", model.description());
+ Assertions.assertEquals("eylaulpuexy", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("tdpfz").type());
+ Assertions.assertEquals("dvdpfgwdxm", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OracleServiceCloudObjectDataset model = new OracleServiceCloudObjectDataset().withDescription("aehjjirvjq")
- .withStructure("datavqmdmrac")
- .withSchema("dataffdralihhs")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("cygyzhcv")
- .withParameters(mapOf("dxrmyzvti", "datayrjl")))
- .withParameters(mapOf("xoyjyhutwedigiv",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datarubx"), "mcaxbqpmfhji",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataccxfnatn"), "lzvrchmy",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanbdqitghnm"), "h",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datarmwy")))
- .withAnnotations(Arrays.asList("dataplgqqqgrbr", "datahvipgt"))
- .withFolder(new DatasetFolder().withName("aoylwhfm"))
- .withTableName("datakkv");
+ OracleServiceCloudObjectDataset model = new OracleServiceCloudObjectDataset().withDescription("grufsdbkuxkdi")
+ .withStructure("datagsivxwkscwbsh")
+ .withSchema("datahvlms")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("eylaulpuexy")
+ .withParameters(mapOf("lspgnndefyhsb", "dataztyecxd", "ltaprq", "datahwlvsvs", "cuhbgftfvqukkmvz",
+ "datafkmvzrkpmonxdw", "dqrjylwqqsemjhh", "dataneg")))
+ .withParameters(mapOf("tdpfz",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataehztbejrdzwy"),
+ "mjkykqflkm", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataifnjwj"),
+ "hc",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataxmysmkbndnrihpja"),
+ "ig", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datajn")))
+ .withAnnotations(Arrays.asList("datalkrnpsbnmrmhkip"))
+ .withFolder(new DatasetFolder().withName("dvdpfgwdxm"))
+ .withTableName("datasyajmmczupd");
model = BinaryData.fromObject(model).toObject(OracleServiceCloudObjectDataset.class);
- Assertions.assertEquals("aehjjirvjq", model.description());
- Assertions.assertEquals("cygyzhcv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("xoyjyhutwedigiv").type());
- Assertions.assertEquals("aoylwhfm", model.folder().name());
+ Assertions.assertEquals("grufsdbkuxkdi", model.description());
+ Assertions.assertEquals("eylaulpuexy", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("tdpfz").type());
+ Assertions.assertEquals("dvdpfgwdxm", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudSourceTests.java
index a5e49c02c6db..b4da198118a5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleServiceCloudSourceTests.java
@@ -11,19 +11,19 @@ public final class OracleServiceCloudSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OracleServiceCloudSource model = BinaryData.fromString(
- "{\"type\":\"OracleServiceCloudSource\",\"query\":\"datanazjvyiiezdnez\",\"queryTimeout\":\"dataqzd\",\"additionalColumns\":\"datamyutzttroymi\",\"sourceRetryCount\":\"datakuz\",\"sourceRetryWait\":\"datacegyztzhcfuwm\",\"maxConcurrentConnections\":\"dataz\",\"disableMetricsCollection\":\"datamklroogflh\",\"\":{\"yokjwsszyetwoukd\":\"datapxb\",\"jihnzvoeh\":\"datanferdg\",\"kghg\":\"datawgqgc\",\"hvnexnwxqwcx\":\"datazjxouxigdwpgmh\"}}")
+ "{\"type\":\"OracleServiceCloudSource\",\"query\":\"datanywwkdxqqgysxpa\",\"queryTimeout\":\"datamthdqvcifwknlyt\",\"additionalColumns\":\"datartocadtnmqrpj\",\"sourceRetryCount\":\"datajixcya\",\"sourceRetryWait\":\"dataii\",\"maxConcurrentConnections\":\"datadbtrkv\",\"disableMetricsCollection\":\"datauessuuzfrw\",\"\":{\"sfbkrtpu\":\"datarngjqc\",\"jjbvv\":\"datapyeyqsini\"}}")
.toObject(OracleServiceCloudSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OracleServiceCloudSource model = new OracleServiceCloudSource().withSourceRetryCount("datakuz")
- .withSourceRetryWait("datacegyztzhcfuwm")
- .withMaxConcurrentConnections("dataz")
- .withDisableMetricsCollection("datamklroogflh")
- .withQueryTimeout("dataqzd")
- .withAdditionalColumns("datamyutzttroymi")
- .withQuery("datanazjvyiiezdnez");
+ OracleServiceCloudSource model = new OracleServiceCloudSource().withSourceRetryCount("datajixcya")
+ .withSourceRetryWait("dataii")
+ .withMaxConcurrentConnections("datadbtrkv")
+ .withDisableMetricsCollection("datauessuuzfrw")
+ .withQueryTimeout("datamthdqvcifwknlyt")
+ .withAdditionalColumns("datartocadtnmqrpj")
+ .withQuery("datanywwkdxqqgysxpa");
model = BinaryData.fromObject(model).toObject(OracleServiceCloudSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSinkTests.java
index 17b28d9b0a17..3f5945bba861 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSinkTests.java
@@ -11,19 +11,19 @@ public final class OracleSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OracleSink model = BinaryData.fromString(
- "{\"type\":\"OracleSink\",\"preCopyScript\":\"datazl\",\"writeBatchSize\":\"datah\",\"writeBatchTimeout\":\"datasdnfppkyk\",\"sinkRetryCount\":\"dataycyfubgnml\",\"sinkRetryWait\":\"datada\",\"maxConcurrentConnections\":\"dataohu\",\"disableMetricsCollection\":\"datapn\",\"\":{\"ng\":\"dataut\",\"ztmq\":\"datad\",\"cokpfyo\":\"datau\",\"vmsf\":\"dataf\"}}")
+ "{\"type\":\"OracleSink\",\"preCopyScript\":\"datagal\",\"writeBatchSize\":\"dataflzuztd\",\"writeBatchTimeout\":\"dataroambzprhpwwarzj\",\"sinkRetryCount\":\"databwtag\",\"sinkRetryWait\":\"datariruvjizukyx\",\"maxConcurrentConnections\":\"datalyjdbsx\",\"disableMetricsCollection\":\"dataleqsk\",\"\":{\"brsmy\":\"datalagbellpkp\"}}")
.toObject(OracleSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OracleSink model = new OracleSink().withWriteBatchSize("datah")
- .withWriteBatchTimeout("datasdnfppkyk")
- .withSinkRetryCount("dataycyfubgnml")
- .withSinkRetryWait("datada")
- .withMaxConcurrentConnections("dataohu")
- .withDisableMetricsCollection("datapn")
- .withPreCopyScript("datazl");
+ OracleSink model = new OracleSink().withWriteBatchSize("dataflzuztd")
+ .withWriteBatchTimeout("dataroambzprhpwwarzj")
+ .withSinkRetryCount("databwtag")
+ .withSinkRetryWait("datariruvjizukyx")
+ .withMaxConcurrentConnections("datalyjdbsx")
+ .withDisableMetricsCollection("dataleqsk")
+ .withPreCopyScript("datagal");
model = BinaryData.fromObject(model).toObject(OracleSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSourceTests.java
index baa338584bdd..9301f2e61fdc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleSourceTests.java
@@ -12,24 +12,24 @@ public final class OracleSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OracleSource model = BinaryData.fromString(
- "{\"type\":\"OracleSource\",\"oracleReaderQuery\":\"datarnknnql\",\"queryTimeout\":\"datagyeyxmuwgnwxtm\",\"partitionOption\":\"datagencmoswcxlg\",\"partitionSettings\":{\"partitionNames\":\"dataqxewsvqpifza\",\"partitionColumnName\":\"datatywap\",\"partitionUpperBound\":\"dataczprzrsqcu\",\"partitionLowerBound\":\"datanp\"},\"additionalColumns\":\"dataqlanuhmsrnp\",\"sourceRetryCount\":\"dataaghoeqiwpdxpd\",\"sourceRetryWait\":\"dataoajqxyplhsto\",\"maxConcurrentConnections\":\"datayb\",\"disableMetricsCollection\":\"dataysvpikgqjdog\",\"\":{\"qpsiniidaxbesb\":\"datajfgyivsiirxcxp\",\"zyjchduasjrseqp\":\"datac\"}}")
+ "{\"type\":\"OracleSource\",\"oracleReaderQuery\":\"datalwlppoh\",\"queryTimeout\":\"datafgalexy\",\"partitionOption\":\"datagkadtwd\",\"partitionSettings\":{\"partitionNames\":\"datajxtfvxcjd\",\"partitionColumnName\":\"datasg\",\"partitionUpperBound\":\"datayjkwltnsn\",\"partitionLowerBound\":\"datavm\"},\"additionalColumns\":\"dataihsclpnbidnlodkq\",\"sourceRetryCount\":\"datankptixawoyzg\",\"sourceRetryWait\":\"datavrygg\",\"maxConcurrentConnections\":\"datacp\",\"disableMetricsCollection\":\"datahoplqtzgtpsbym\",\"\":{\"rqzbqy\":\"datat\",\"ahbynlbwcnnfp\":\"datagfqqrarolc\"}}")
.toObject(OracleSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OracleSource model = new OracleSource().withSourceRetryCount("dataaghoeqiwpdxpd")
- .withSourceRetryWait("dataoajqxyplhsto")
- .withMaxConcurrentConnections("datayb")
- .withDisableMetricsCollection("dataysvpikgqjdog")
- .withOracleReaderQuery("datarnknnql")
- .withQueryTimeout("datagyeyxmuwgnwxtm")
- .withPartitionOption("datagencmoswcxlg")
- .withPartitionSettings(new OraclePartitionSettings().withPartitionNames("dataqxewsvqpifza")
- .withPartitionColumnName("datatywap")
- .withPartitionUpperBound("dataczprzrsqcu")
- .withPartitionLowerBound("datanp"))
- .withAdditionalColumns("dataqlanuhmsrnp");
+ OracleSource model = new OracleSource().withSourceRetryCount("datankptixawoyzg")
+ .withSourceRetryWait("datavrygg")
+ .withMaxConcurrentConnections("datacp")
+ .withDisableMetricsCollection("datahoplqtzgtpsbym")
+ .withOracleReaderQuery("datalwlppoh")
+ .withQueryTimeout("datafgalexy")
+ .withPartitionOption("datagkadtwd")
+ .withPartitionSettings(new OraclePartitionSettings().withPartitionNames("datajxtfvxcjd")
+ .withPartitionColumnName("datasg")
+ .withPartitionUpperBound("datayjkwltnsn")
+ .withPartitionLowerBound("datavm"))
+ .withAdditionalColumns("dataihsclpnbidnlodkq");
model = BinaryData.fromObject(model).toObject(OracleSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTests.java
index 59fc0774241a..bc57c556c7eb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTests.java
@@ -19,37 +19,36 @@ public final class OracleTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OracleTableDataset model = BinaryData.fromString(
- "{\"type\":\"OracleTable\",\"typeProperties\":{\"tableName\":\"databn\",\"schema\":\"datanv\",\"table\":\"datahfuzzlapyixlvz\"},\"description\":\"ulaebx\",\"structure\":\"datauq\",\"schema\":\"dataptessjlw\",\"linkedServiceName\":{\"referenceName\":\"tatpvblskxgxqay\",\"parameters\":{\"jbvyezjwjkqo\":\"datalkvcvwpvl\",\"ieyozvrcwfpucwnb\":\"databwh\"}},\"parameters\":{\"xtuuci\":{\"type\":\"String\",\"defaultValue\":\"datagzjvbxqcbgoa\"},\"mjfexulvoep\":{\"type\":\"String\",\"defaultValue\":\"datakdlhuduklbjoa\"},\"qoacbuqdgsap\":{\"type\":\"String\",\"defaultValue\":\"datarseianc\"}},\"annotations\":[\"datafgkxenvs\"],\"folder\":{\"name\":\"vya\"},\"\":{\"uuvu\":\"dataz\"}}")
+ "{\"type\":\"OracleTable\",\"typeProperties\":{\"tableName\":\"datazsxagysokli\",\"schema\":\"datas\",\"table\":\"datavrrbnhy\"},\"description\":\"bhujcydyl\",\"structure\":\"dataxvpstizsyqagqll\",\"schema\":\"datar\",\"linkedServiceName\":{\"referenceName\":\"aidyl\",\"parameters\":{\"jrnogykugdl\":\"datatrrqwfyybptm\",\"gthkslgeu\":\"datavsa\"}},\"parameters\":{\"lajybdnb\":{\"type\":\"String\",\"defaultValue\":\"databfbxj\"},\"zdjmofsvpzxgny\":{\"type\":\"String\",\"defaultValue\":\"databtois\"},\"ymg\":{\"type\":\"String\",\"defaultValue\":\"dataymlf\"}},\"annotations\":[\"dataszcfyzqpeqreg\",\"dataurd\"],\"folder\":{\"name\":\"knxmaovrgihlnz\"},\"\":{\"yafwtyd\":\"datawvqkycjcgeipqxxs\",\"hg\":\"datamma\",\"adj\":\"datalejqzhpvhxp\",\"qscjpvqerqxk\":\"dataeullgfyog\"}}")
.toObject(OracleTableDataset.class);
- Assertions.assertEquals("ulaebx", model.description());
- Assertions.assertEquals("tatpvblskxgxqay", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("xtuuci").type());
- Assertions.assertEquals("vya", model.folder().name());
+ Assertions.assertEquals("bhujcydyl", model.description());
+ Assertions.assertEquals("aidyl", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("lajybdnb").type());
+ Assertions.assertEquals("knxmaovrgihlnz", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OracleTableDataset model = new OracleTableDataset().withDescription("ulaebx")
- .withStructure("datauq")
- .withSchema("dataptessjlw")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tatpvblskxgxqay")
- .withParameters(mapOf("jbvyezjwjkqo", "datalkvcvwpvl", "ieyozvrcwfpucwnb", "databwh")))
- .withParameters(mapOf("xtuuci",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datagzjvbxqcbgoa"),
- "mjfexulvoep",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datakdlhuduklbjoa"),
- "qoacbuqdgsap",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datarseianc")))
- .withAnnotations(Arrays.asList("datafgkxenvs"))
- .withFolder(new DatasetFolder().withName("vya"))
- .withTableName("databn")
- .withSchemaTypePropertiesSchema("datanv")
- .withTable("datahfuzzlapyixlvz");
+ OracleTableDataset model = new OracleTableDataset().withDescription("bhujcydyl")
+ .withStructure("dataxvpstizsyqagqll")
+ .withSchema("datar")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("aidyl")
+ .withParameters(mapOf("jrnogykugdl", "datatrrqwfyybptm", "gthkslgeu", "datavsa")))
+ .withParameters(mapOf("lajybdnb",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("databfbxj"),
+ "zdjmofsvpzxgny",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("databtois"), "ymg",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataymlf")))
+ .withAnnotations(Arrays.asList("dataszcfyzqpeqreg", "dataurd"))
+ .withFolder(new DatasetFolder().withName("knxmaovrgihlnz"))
+ .withTableName("datazsxagysokli")
+ .withSchemaTypePropertiesSchema("datas")
+ .withTable("datavrrbnhy");
model = BinaryData.fromObject(model).toObject(OracleTableDataset.class);
- Assertions.assertEquals("ulaebx", model.description());
- Assertions.assertEquals("tatpvblskxgxqay", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("xtuuci").type());
- Assertions.assertEquals("vya", model.folder().name());
+ Assertions.assertEquals("bhujcydyl", model.description());
+ Assertions.assertEquals("aidyl", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("lajybdnb").type());
+ Assertions.assertEquals("knxmaovrgihlnz", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTypePropertiesTests.java
index 4c052ff8c74d..ca938b621ded 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OracleTableDatasetTypePropertiesTests.java
@@ -10,16 +10,16 @@
public final class OracleTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- OracleTableDatasetTypeProperties model = BinaryData.fromString(
- "{\"tableName\":\"dataqcwggchxvl\",\"schema\":\"datafbrvecicaovphirl\",\"table\":\"dataipiunnepkwzzzku\"}")
+ OracleTableDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"datawdzpzl\",\"schema\":\"datauexlqpww\",\"table\":\"databjecfwl\"}")
.toObject(OracleTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OracleTableDatasetTypeProperties model = new OracleTableDatasetTypeProperties().withTableName("dataqcwggchxvl")
- .withSchema("datafbrvecicaovphirl")
- .withTable("dataipiunnepkwzzzku");
+ OracleTableDatasetTypeProperties model = new OracleTableDatasetTypeProperties().withTableName("datawdzpzl")
+ .withSchema("datauexlqpww")
+ .withTable("databjecfwl");
model = BinaryData.fromObject(model).toObject(OracleTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSinkTests.java
index 17b6d076d71a..8213cdc29972 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSinkTests.java
@@ -17,27 +17,26 @@ public final class OrcSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OrcSink model = BinaryData.fromString(
- "{\"type\":\"OrcSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datazzbr\",\"disableMetricsCollection\":\"datakeylk\",\"copyBehavior\":\"dataaagrdfwvgl\",\"metadata\":[{\"name\":\"datahvo\",\"value\":\"datacryhuohthzfot\"},{\"name\":\"datafhrjkah\",\"value\":\"datafshgmqxwoppn\"},{\"name\":\"datarmzv\",\"value\":\"datafkznyait\"}],\"\":{\"rjmilog\":\"dataobrxhwpgkrn\",\"btplrtxhztufwyrs\":\"datanzfgqi\",\"buyd\":\"datajjsoyus\"}},\"formatSettings\":{\"type\":\"OrcWriteSettings\",\"maxRowsPerFile\":\"dataknttkdrblehen\",\"fileNamePrefix\":\"datat\",\"\":{\"bijikjf\":\"dataeo\",\"whbpojujpifxtg\":\"dataib\"}},\"writeBatchSize\":\"dataavfjx\",\"writeBatchTimeout\":\"datawx\",\"sinkRetryCount\":\"dataauh\",\"sinkRetryWait\":\"datachphovu\",\"maxConcurrentConnections\":\"datasczwcxlncoh\",\"disableMetricsCollection\":\"datafvyriawfwwsgdkbd\",\"\":{\"rtoxsthjyyiryb\":\"dataspfwmfc\"}}")
+ "{\"type\":\"OrcSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datadtuhdoimojcm\",\"disableMetricsCollection\":\"datacd\",\"copyBehavior\":\"datavorzhzfoc\",\"metadata\":[{\"name\":\"datatornvbhuyolwifbd\",\"value\":\"datavvcyw\"},{\"name\":\"datavkthrexzve\",\"value\":\"datazyuiklokeqeowb\"}],\"\":{\"bpobvjhun\":\"dataehvgchsgotgwe\",\"rxcei\":\"datac\",\"dtkllqhznutrx\":\"datav\"}},\"formatSettings\":{\"type\":\"OrcWriteSettings\",\"maxRowsPerFile\":\"datatrnniarjezjhy\",\"fileNamePrefix\":\"dataqf\",\"\":{\"ipshhetagwm\":\"dataesqykqfserls\",\"kehpdssvlubdp\":\"datagvnojgmobkaligoi\",\"mixu\":\"dataowxsxbxd\",\"hmtbu\":\"datacekcqmjqqauft\"}},\"writeBatchSize\":\"datacnkghkrbirshlh\",\"writeBatchTimeout\":\"datayod\",\"sinkRetryCount\":\"datawnqbpxy\",\"sinkRetryWait\":\"dataftxzovbhqels\",\"maxConcurrentConnections\":\"datafxejpocsgigsab\",\"disableMetricsCollection\":\"datandyjwmglgstrzfhe\",\"\":{\"ohnymfhmlji\":\"dataovkbcbe\",\"iszxdbg\":\"datakgfvzvmtjcxi\",\"izw\":\"dataceetuivmbu\"}}")
.toObject(OrcSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OrcSink model = new OrcSink().withWriteBatchSize("dataavfjx")
- .withWriteBatchTimeout("datawx")
- .withSinkRetryCount("dataauh")
- .withSinkRetryWait("datachphovu")
- .withMaxConcurrentConnections("datasczwcxlncoh")
- .withDisableMetricsCollection("datafvyriawfwwsgdkbd")
- .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datazzbr")
- .withDisableMetricsCollection("datakeylk")
- .withCopyBehavior("dataaagrdfwvgl")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datahvo").withValue("datacryhuohthzfot"),
- new MetadataItem().withName("datafhrjkah").withValue("datafshgmqxwoppn"),
- new MetadataItem().withName("datarmzv").withValue("datafkznyait")))
+ OrcSink model = new OrcSink().withWriteBatchSize("datacnkghkrbirshlh")
+ .withWriteBatchTimeout("datayod")
+ .withSinkRetryCount("datawnqbpxy")
+ .withSinkRetryWait("dataftxzovbhqels")
+ .withMaxConcurrentConnections("datafxejpocsgigsab")
+ .withDisableMetricsCollection("datandyjwmglgstrzfhe")
+ .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datadtuhdoimojcm")
+ .withDisableMetricsCollection("datacd")
+ .withCopyBehavior("datavorzhzfoc")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datatornvbhuyolwifbd").withValue("datavvcyw"),
+ new MetadataItem().withName("datavkthrexzve").withValue("datazyuiklokeqeowb")))
.withAdditionalProperties(mapOf("type", "StoreWriteSettings")))
.withFormatSettings(
- new OrcWriteSettings().withMaxRowsPerFile("dataknttkdrblehen").withFileNamePrefix("datat"));
+ new OrcWriteSettings().withMaxRowsPerFile("datatrnniarjezjhy").withFileNamePrefix("dataqf"));
model = BinaryData.fromObject(model).toObject(OrcSink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSourceTests.java
index f629fa4426f3..2a9e3ae15667 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcSourceTests.java
@@ -14,20 +14,20 @@ public final class OrcSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OrcSource model = BinaryData.fromString(
- "{\"type\":\"OrcSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datayrttnrikssqfiksj\",\"disableMetricsCollection\":\"dataignmtoqtuivipb\",\"\":{\"kkkgiecjyf\":\"datapslpevzpqydn\",\"f\":\"datasn\",\"tjc\":\"dataz\"}},\"additionalColumns\":\"dataqx\",\"sourceRetryCount\":\"datakqmagpdsuyyw\",\"sourceRetryWait\":\"dataqg\",\"maxConcurrentConnections\":\"dataxuhhvgddfzcny\",\"disableMetricsCollection\":\"datawlhuf\",\"\":{\"gfhof\":\"datapwrtgtd\",\"tjjfecxv\":\"dataptbiuikp\",\"p\":\"dataqjpovjvv\"}}")
+ "{\"type\":\"OrcSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datagolfensibqi\",\"disableMetricsCollection\":\"datapyjzv\",\"\":{\"vz\":\"datalfs\"}},\"additionalColumns\":\"datavvwroug\",\"sourceRetryCount\":\"dataywgqrevbobheyx\",\"sourceRetryWait\":\"datacsktvkwb\",\"maxConcurrentConnections\":\"datakfvvxiikrja\",\"disableMetricsCollection\":\"datatvnmr\",\"\":{\"mhksgouzvegtnph\":\"dataypuotmkbofu\",\"aetsdufegb\":\"dataotrgyyjeagovjdun\",\"gzrzubdtzsac\":\"datavkuz\",\"kbxkzcfios\":\"datamhzpurnp\"}}")
.toObject(OrcSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- OrcSource model = new OrcSource().withSourceRetryCount("datakqmagpdsuyyw")
- .withSourceRetryWait("dataqg")
- .withMaxConcurrentConnections("dataxuhhvgddfzcny")
- .withDisableMetricsCollection("datawlhuf")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datayrttnrikssqfiksj")
- .withDisableMetricsCollection("dataignmtoqtuivipb")
+ OrcSource model = new OrcSource().withSourceRetryCount("dataywgqrevbobheyx")
+ .withSourceRetryWait("datacsktvkwb")
+ .withMaxConcurrentConnections("datakfvvxiikrja")
+ .withDisableMetricsCollection("datatvnmr")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datagolfensibqi")
+ .withDisableMetricsCollection("datapyjzv")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
- .withAdditionalColumns("dataqx");
+ .withAdditionalColumns("datavvwroug");
model = BinaryData.fromObject(model).toObject(OrcSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcWriteSettingsTests.java
index 79bc3bb02f70..a0c926fa24bb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/OrcWriteSettingsTests.java
@@ -11,14 +11,14 @@ public final class OrcWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
OrcWriteSettings model = BinaryData.fromString(
- "{\"type\":\"OrcWriteSettings\",\"maxRowsPerFile\":\"datambjr\",\"fileNamePrefix\":\"dataiufqxrlzij\",\"\":{\"gmcmlzmfetidnewr\":\"dataz\",\"gowdavpqyhax\":\"datajgwnmxc\",\"gkwpbnefabgt\":\"dataorzozf\",\"ugddycfyfau\":\"dataggoppmxcm\"}}")
+ "{\"type\":\"OrcWriteSettings\",\"maxRowsPerFile\":\"datajqpxydpamctz\",\"fileNamePrefix\":\"datarhccdgunsjssreo\",\"\":{\"pgkxyrsppbghy\":\"datakoue\",\"awlqvuwsqmwqsgy\":\"datakgg\",\"o\":\"dataz\",\"ursumbci\":\"datatngxvrpkizjnkgd\"}}")
.toObject(OrcWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
OrcWriteSettings model
- = new OrcWriteSettings().withMaxRowsPerFile("datambjr").withFileNamePrefix("dataiufqxrlzij");
+ = new OrcWriteSettings().withMaxRowsPerFile("datajqpxydpamctz").withFileNamePrefix("datarhccdgunsjssreo");
model = BinaryData.fromObject(model).toObject(OrcWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PackageStoreTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PackageStoreTests.java
index f5b5058936e4..edb32f20345f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PackageStoreTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PackageStoreTests.java
@@ -14,24 +14,24 @@ public final class PackageStoreTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PackageStore model = BinaryData.fromString(
- "{\"name\":\"gunrukcyyaa\",\"packageStoreLinkedService\":{\"type\":\"IntegrationRuntimeReference\",\"referenceName\":\"bzqa\"}}")
+ "{\"name\":\"nhyyqxckd\",\"packageStoreLinkedService\":{\"type\":\"LinkedServiceReference\",\"referenceName\":\"isrdnowinc\"}}")
.toObject(PackageStore.class);
- Assertions.assertEquals("gunrukcyyaa", model.name());
- Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE,
+ Assertions.assertEquals("nhyyqxckd", model.name());
+ Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE,
model.packageStoreLinkedService().type());
- Assertions.assertEquals("bzqa", model.packageStoreLinkedService().referenceName());
+ Assertions.assertEquals("isrdnowinc", model.packageStoreLinkedService().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PackageStore model = new PackageStore().withName("gunrukcyyaa")
+ PackageStore model = new PackageStore().withName("nhyyqxckd")
.withPackageStoreLinkedService(
- new EntityReference().withType(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE)
- .withReferenceName("bzqa"));
+ new EntityReference().withType(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE)
+ .withReferenceName("isrdnowinc"));
model = BinaryData.fromObject(model).toObject(PackageStore.class);
- Assertions.assertEquals("gunrukcyyaa", model.name());
- Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.INTEGRATION_RUNTIME_REFERENCE,
+ Assertions.assertEquals("nhyyqxckd", model.name());
+ Assertions.assertEquals(IntegrationRuntimeEntityReferenceType.LINKED_SERVICE_REFERENCE,
model.packageStoreLinkedService().type());
- Assertions.assertEquals("bzqa", model.packageStoreLinkedService().referenceName());
+ Assertions.assertEquals("isrdnowinc", model.packageStoreLinkedService().referenceName());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetReadSettingsTests.java
index 20492a3109da..41430c1d5288 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetReadSettingsTests.java
@@ -14,7 +14,7 @@ public final class ParquetReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ParquetReadSettings model = BinaryData.fromString(
- "{\"type\":\"ParquetReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"q\":\"dataqzikvg\",\"rzxvffq\":\"datawodhaslpaae\",\"mhrztbyulk\":\"dataht\",\"qcidiwkxikxiqxl\":\"dataepssoqdibyg\"}},\"\":{\"pftrdicstrbq\":\"datasy\",\"katccetyyv\":\"dataatkliopgw\",\"nsdp\":\"datakwobb\"}}")
+ "{\"type\":\"ParquetReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"efabgtcggoppm\":\"datapb\"}},\"\":{\"mzq\":\"dataougddycfyfaun\"}}")
.toObject(ParquetReadSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSinkTests.java
index d378ebea52d3..6e70b0db1c41 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSinkTests.java
@@ -17,28 +17,25 @@ public final class ParquetSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ParquetSink model = BinaryData.fromString(
- "{\"type\":\"ParquetSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"dataxazuboigorwpbbjz\",\"disableMetricsCollection\":\"dataaqoilgkznnzpvjw\",\"copyBehavior\":\"dataoviceqyrajdvvsa\",\"metadata\":[{\"name\":\"datapercazcchvwwcha\",\"value\":\"datatvotfhhayfxkf\"},{\"name\":\"dataxefzliguw\",\"value\":\"dataszcmfmynljigjc\"},{\"name\":\"dataa\",\"value\":\"datawtivsk\"}],\"\":{\"hbxvvu\":\"datapnpunrvjb\",\"kj\":\"dataq\"}},\"formatSettings\":{\"type\":\"ParquetWriteSettings\",\"maxRowsPerFile\":\"dataajqnsrcqd\",\"fileNamePrefix\":\"datamlqamd\",\"\":{\"r\":\"datakdmr\",\"lsnprda\":\"dataakc\"}},\"writeBatchSize\":\"dataqgabbxexacgmt\",\"writeBatchTimeout\":\"dataxb\",\"sinkRetryCount\":\"databovexsnmww\",\"sinkRetryWait\":\"datamujlsztpygqwkd\",\"maxConcurrentConnections\":\"datasn\",\"disableMetricsCollection\":\"datakci\",\"\":{\"dn\":\"datafejzmyvlbzmngxz\"}}")
+ "{\"type\":\"ParquetSink\",\"storeSettings\":{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datadzh\",\"disableMetricsCollection\":\"datappqcgbp\",\"copyBehavior\":\"datani\",\"metadata\":[{\"name\":\"datalxuptbtl\",\"value\":\"datarjbakpasuugc\"}],\"\":{\"aimkoyrppsnljd\":\"dataulvdenhgu\",\"xbjqiabitevv\":\"datawkbozlmrhnghvlvd\"}},\"formatSettings\":{\"type\":\"ParquetWriteSettings\",\"maxRowsPerFile\":\"dataypyljz\",\"fileNamePrefix\":\"datakdfyvgcftaqydcr\",\"\":{\"azmrejzpxoqegerx\":\"datamneykxewem\",\"rt\":\"datalfnuglmyr\",\"zwgrs\":\"datakpo\",\"jzq\":\"dataitlmcaehjhwkl\"}},\"writeBatchSize\":\"dataypanwejbngojna\",\"writeBatchTimeout\":\"datawytkwtf\",\"sinkRetryCount\":\"dataafks\",\"sinkRetryWait\":\"datamfhruhw\",\"maxConcurrentConnections\":\"datanrdf\",\"disableMetricsCollection\":\"databhrvonea\",\"\":{\"to\":\"datamjigypbdfrtasaur\",\"ynn\":\"datalxojijttsyr\"}}")
.toObject(ParquetSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ParquetSink model = new ParquetSink().withWriteBatchSize("dataqgabbxexacgmt")
- .withWriteBatchTimeout("dataxb")
- .withSinkRetryCount("databovexsnmww")
- .withSinkRetryWait("datamujlsztpygqwkd")
- .withMaxConcurrentConnections("datasn")
- .withDisableMetricsCollection("datakci")
- .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("dataxazuboigorwpbbjz")
- .withDisableMetricsCollection("dataaqoilgkznnzpvjw")
- .withCopyBehavior("dataoviceqyrajdvvsa")
- .withMetadata(
- Arrays.asList(new MetadataItem().withName("datapercazcchvwwcha").withValue("datatvotfhhayfxkf"),
- new MetadataItem().withName("dataxefzliguw").withValue("dataszcmfmynljigjc"),
- new MetadataItem().withName("dataa").withValue("datawtivsk")))
+ ParquetSink model = new ParquetSink().withWriteBatchSize("dataypanwejbngojna")
+ .withWriteBatchTimeout("datawytkwtf")
+ .withSinkRetryCount("dataafks")
+ .withSinkRetryWait("datamfhruhw")
+ .withMaxConcurrentConnections("datanrdf")
+ .withDisableMetricsCollection("databhrvonea")
+ .withStoreSettings(new StoreWriteSettings().withMaxConcurrentConnections("datadzh")
+ .withDisableMetricsCollection("datappqcgbp")
+ .withCopyBehavior("datani")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datalxuptbtl").withValue("datarjbakpasuugc")))
.withAdditionalProperties(mapOf("type", "StoreWriteSettings")))
.withFormatSettings(
- new ParquetWriteSettings().withMaxRowsPerFile("dataajqnsrcqd").withFileNamePrefix("datamlqamd"));
+ new ParquetWriteSettings().withMaxRowsPerFile("dataypyljz").withFileNamePrefix("datakdfyvgcftaqydcr"));
model = BinaryData.fromObject(model).toObject(ParquetSink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSourceTests.java
index d7700757b6e4..550b820c4dd3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetSourceTests.java
@@ -16,22 +16,22 @@ public final class ParquetSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ParquetSource model = BinaryData.fromString(
- "{\"type\":\"ParquetSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datackfu\",\"disableMetricsCollection\":\"datachotdzt\",\"\":{\"lnsdazqcem\":\"datahwpuaermaw\",\"thisxzhik\":\"dataotwfu\",\"qojpg\":\"datadfszxbups\"}},\"formatSettings\":{\"type\":\"ParquetReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"zlmwfncwlwov\":\"datahyvtajwkrx\",\"aljwfnc\":\"datazbomjbyssprkbz\"}},\"\":{\"ppqajdm\":\"dataylcpgzmxr\",\"wrziminetb\":\"dataunntqqguhv\",\"kedlclxxq\":\"datafwfuxdtpjcs\"}},\"additionalColumns\":\"dataf\",\"sourceRetryCount\":\"dataqombdsgqxacidu\",\"sourceRetryWait\":\"datazzhdjbyfdfu\",\"maxConcurrentConnections\":\"datanhpyylek\",\"disableMetricsCollection\":\"dataiw\",\"\":{\"qb\":\"datazzny\",\"ttkbzwgj\":\"dataxpwjvfisloq\",\"jqsshu\":\"datapjbdqmnki\",\"uwome\":\"dataxjttnurkmerqza\"}}")
+ "{\"type\":\"ParquetSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datamzdnvno\",\"disableMetricsCollection\":\"datalgrenuqsgertx\",\"\":{\"aedbsl\":\"datamgsncbbdokp\",\"k\":\"datanunpxswmcc\"}},\"formatSettings\":{\"type\":\"ParquetReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"dc\":\"dataepxlxbo\"}},\"\":{\"sojwoixt\":\"dataacfskzwesetutq\",\"jka\":\"datanakytzcmagvs\"}},\"additionalColumns\":\"dataqh\",\"sourceRetryCount\":\"datawqhz\",\"sourceRetryWait\":\"datagmg\",\"maxConcurrentConnections\":\"datagmtywivbu\",\"disableMetricsCollection\":\"dataeedjnklvbrsxykwb\",\"\":{\"t\":\"datadudj\"}}")
.toObject(ParquetSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ParquetSource model = new ParquetSource().withSourceRetryCount("dataqombdsgqxacidu")
- .withSourceRetryWait("datazzhdjbyfdfu")
- .withMaxConcurrentConnections("datanhpyylek")
- .withDisableMetricsCollection("dataiw")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datackfu")
- .withDisableMetricsCollection("datachotdzt")
+ ParquetSource model = new ParquetSource().withSourceRetryCount("datawqhz")
+ .withSourceRetryWait("datagmg")
+ .withMaxConcurrentConnections("datagmtywivbu")
+ .withDisableMetricsCollection("dataeedjnklvbrsxykwb")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datamzdnvno")
+ .withDisableMetricsCollection("datalgrenuqsgertx")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
.withFormatSettings(new ParquetReadSettings().withCompressionProperties(
new CompressionReadSettings().withAdditionalProperties(mapOf("type", "CompressionReadSettings"))))
- .withAdditionalColumns("dataf");
+ .withAdditionalColumns("dataqh");
model = BinaryData.fromObject(model).toObject(ParquetSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetWriteSettingsTests.java
index 143309e296ab..6630bb5dd297 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ParquetWriteSettingsTests.java
@@ -11,14 +11,14 @@ public final class ParquetWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ParquetWriteSettings model = BinaryData.fromString(
- "{\"type\":\"ParquetWriteSettings\",\"maxRowsPerFile\":\"datamzq\",\"fileNamePrefix\":\"datawkesxvzcxxf\",\"\":{\"zkmgylmycx\":\"datapgqwb\"}}")
+ "{\"type\":\"ParquetWriteSettings\",\"maxRowsPerFile\":\"datab\",\"fileNamePrefix\":\"datapsv\",\"\":{\"umuuyblolruf\":\"datah\",\"lbq\":\"datamg\",\"mxyjqhwsojnbbbgv\":\"datals\"}}")
.toObject(ParquetWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
ParquetWriteSettings model
- = new ParquetWriteSettings().withMaxRowsPerFile("datamzq").withFileNamePrefix("datawkesxvzcxxf");
+ = new ParquetWriteSettings().withMaxRowsPerFile("datab").withFileNamePrefix("datapsv");
model = BinaryData.fromObject(model).toObject(ParquetWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalObjectDatasetTests.java
index 64c92ede843d..004f28c4cb27 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalObjectDatasetTests.java
@@ -19,36 +19,33 @@ public final class PaypalObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PaypalObjectDataset model = BinaryData.fromString(
- "{\"type\":\"PaypalObject\",\"typeProperties\":{\"tableName\":\"databb\"},\"description\":\"yp\",\"structure\":\"dataodaq\",\"schema\":\"datakp\",\"linkedServiceName\":{\"referenceName\":\"zf\",\"parameters\":{\"valcrqaxlmbrtvtg\":\"databg\"}},\"parameters\":{\"voysxa\":{\"type\":\"Object\",\"defaultValue\":\"datalgtlayyxhx\"},\"njc\":{\"type\":\"SecureString\",\"defaultValue\":\"datahdfhfaob\"},\"ydvwr\":{\"type\":\"SecureString\",\"defaultValue\":\"datazvcdqws\"},\"dlxbaeyocpkv\":{\"type\":\"Int\",\"defaultValue\":\"datavywotjnjuvtzij\"}},\"annotations\":[\"datafdz\",\"datamnpbdrcibj\",\"datannno\",\"datatnhvdtu\"],\"folder\":{\"name\":\"qobqehspshtisy\"},\"\":{\"zeb\":\"dataoctrzjwnzwc\",\"lmlnxrcatkuh\":\"databvwdxgyypmxq\",\"gdkvviilyeshoxf\":\"datak\"}}")
+ "{\"type\":\"PaypalObject\",\"typeProperties\":{\"tableName\":\"dataamqobqehs\"},\"description\":\"htisyzfeoctr\",\"structure\":\"datawn\",\"schema\":\"datackze\",\"linkedServiceName\":{\"referenceName\":\"mbvwdxgy\",\"parameters\":{\"atkuhskegd\":\"dataxqzlmlnxr\",\"l\":\"datavvi\"}},\"parameters\":{\"pbusxy\":{\"type\":\"Int\",\"defaultValue\":\"dataxfzzjdm\"},\"kkbyg\":{\"type\":\"String\",\"defaultValue\":\"datazwplxzgzumnotii\"},\"wyshybbnhtt\":{\"type\":\"Array\",\"defaultValue\":\"dataq\"}},\"annotations\":[\"dataonzsurqcoj\",\"datasfzhzzcarciuoxyi\",\"datadthjfvnhwsgnsput\",\"datae\"],\"folder\":{\"name\":\"hnu\"},\"\":{\"h\":\"datajgbfbba\",\"vkbuxlepg\":\"dataxczzunfnbphcee\",\"tfsclgga\":\"datacnuqhqpvtw\"}}")
.toObject(PaypalObjectDataset.class);
- Assertions.assertEquals("yp", model.description());
- Assertions.assertEquals("zf", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("voysxa").type());
- Assertions.assertEquals("qobqehspshtisy", model.folder().name());
+ Assertions.assertEquals("htisyzfeoctr", model.description());
+ Assertions.assertEquals("mbvwdxgy", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("pbusxy").type());
+ Assertions.assertEquals("hnu", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PaypalObjectDataset model = new PaypalObjectDataset().withDescription("yp")
- .withStructure("dataodaq")
- .withSchema("datakp")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zf")
- .withParameters(mapOf("valcrqaxlmbrtvtg", "databg")))
- .withParameters(mapOf("voysxa",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datalgtlayyxhx"), "njc",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datahdfhfaob"),
- "ydvwr",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datazvcdqws"),
- "dlxbaeyocpkv",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datavywotjnjuvtzij")))
- .withAnnotations(Arrays.asList("datafdz", "datamnpbdrcibj", "datannno", "datatnhvdtu"))
- .withFolder(new DatasetFolder().withName("qobqehspshtisy"))
- .withTableName("databb");
+ PaypalObjectDataset model = new PaypalObjectDataset().withDescription("htisyzfeoctr")
+ .withStructure("datawn")
+ .withSchema("datackze")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mbvwdxgy")
+ .withParameters(mapOf("atkuhskegd", "dataxqzlmlnxr", "l", "datavvi")))
+ .withParameters(mapOf("pbusxy",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataxfzzjdm"), "kkbyg",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datazwplxzgzumnotii"),
+ "wyshybbnhtt", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataq")))
+ .withAnnotations(Arrays.asList("dataonzsurqcoj", "datasfzhzzcarciuoxyi", "datadthjfvnhwsgnsput", "datae"))
+ .withFolder(new DatasetFolder().withName("hnu"))
+ .withTableName("dataamqobqehs");
model = BinaryData.fromObject(model).toObject(PaypalObjectDataset.class);
- Assertions.assertEquals("yp", model.description());
- Assertions.assertEquals("zf", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("voysxa").type());
- Assertions.assertEquals("qobqehspshtisy", model.folder().name());
+ Assertions.assertEquals("htisyzfeoctr", model.description());
+ Assertions.assertEquals("mbvwdxgy", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("pbusxy").type());
+ Assertions.assertEquals("hnu", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalSourceTests.java
index 278fd3013760..7ba2aa8c4855 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PaypalSourceTests.java
@@ -11,19 +11,19 @@ public final class PaypalSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PaypalSource model = BinaryData.fromString(
- "{\"type\":\"PaypalSource\",\"query\":\"dataylvrofhhitjhh\",\"queryTimeout\":\"datavwrc\",\"additionalColumns\":\"datahllmblls\",\"sourceRetryCount\":\"datafdrimoopfr\",\"sourceRetryWait\":\"datajjrhxornuoqpob\",\"maxConcurrentConnections\":\"datarsdx\",\"disableMetricsCollection\":\"datamq\",\"\":{\"lseoixqp\":\"databqyavcxj\",\"fsuwcmzpwkca\":\"datamsfqntakroxku\",\"zq\":\"datafq\"}}")
+ "{\"type\":\"PaypalSource\",\"query\":\"datadtq\",\"queryTimeout\":\"datajbxol\",\"additionalColumns\":\"datahquqihgibog\",\"sourceRetryCount\":\"datajupenoupcolxc\",\"sourceRetryWait\":\"dataszwadesisd\",\"maxConcurrentConnections\":\"datauhqts\",\"disableMetricsCollection\":\"datab\",\"\":{\"bymrgelgoduexx\":\"dataeeucvv\",\"fr\":\"datad\",\"wqzvqtnozwphka\":\"dataenvkqtvtq\",\"bzbbjxkami\":\"dataracvcbrtltpo\"}}")
.toObject(PaypalSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PaypalSource model = new PaypalSource().withSourceRetryCount("datafdrimoopfr")
- .withSourceRetryWait("datajjrhxornuoqpob")
- .withMaxConcurrentConnections("datarsdx")
- .withDisableMetricsCollection("datamq")
- .withQueryTimeout("datavwrc")
- .withAdditionalColumns("datahllmblls")
- .withQuery("dataylvrofhhitjhh");
+ PaypalSource model = new PaypalSource().withSourceRetryCount("datajupenoupcolxc")
+ .withSourceRetryWait("dataszwadesisd")
+ .withMaxConcurrentConnections("datauhqts")
+ .withDisableMetricsCollection("datab")
+ .withQueryTimeout("datajbxol")
+ .withAdditionalColumns("datahquqihgibog")
+ .withQuery("datadtq");
model = BinaryData.fromObject(model).toObject(PaypalSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixDatasetTypePropertiesTests.java
index b803c8d2e843..ff7f91b1bc98 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixDatasetTypePropertiesTests.java
@@ -10,16 +10,16 @@
public final class PhoenixDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- PhoenixDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datambdqra\",\"table\":\"datad\",\"schema\":\"dataluobbva\"}")
- .toObject(PhoenixDatasetTypeProperties.class);
+ PhoenixDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"datapi\",\"table\":\"dataromppzsauqmeuhpl\",\"schema\":\"datampuai\"}")
+ .toObject(PhoenixDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PhoenixDatasetTypeProperties model = new PhoenixDatasetTypeProperties().withTableName("datambdqra")
- .withTable("datad")
- .withSchema("dataluobbva");
+ PhoenixDatasetTypeProperties model = new PhoenixDatasetTypeProperties().withTableName("datapi")
+ .withTable("dataromppzsauqmeuhpl")
+ .withSchema("datampuai");
model = BinaryData.fromObject(model).toObject(PhoenixDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixObjectDatasetTests.java
index ceb447e992c4..33b0d497a5de 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixObjectDatasetTests.java
@@ -19,38 +19,36 @@ public final class PhoenixObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PhoenixObjectDataset model = BinaryData.fromString(
- "{\"type\":\"PhoenixObject\",\"typeProperties\":{\"tableName\":\"datadmupbusxyug\",\"table\":\"datawplx\",\"schema\":\"datazu\"},\"description\":\"otiixkkbygbgiq\",\"structure\":\"datayshybb\",\"schema\":\"datattyizonzsurqcoja\",\"linkedServiceName\":{\"referenceName\":\"fzhzzcarciuo\",\"parameters\":{\"hwsgnsputfe\":\"datapdthjfv\",\"hnu\":\"dataf\",\"chxxc\":\"datassjgbfbb\",\"bphceeivkbuxlep\":\"datazunf\"}},\"parameters\":{\"fscl\":{\"type\":\"Object\",\"defaultValue\":\"dataqhqpvtwt\"},\"bfytnhdnihuzzjuz\":{\"type\":\"Bool\",\"defaultValue\":\"datagygn\"},\"tsucrxdtejobjz\":{\"type\":\"Bool\",\"defaultValue\":\"databzdtorbiwnyfzdpx\"}},\"annotations\":[\"datat\",\"datad\",\"datanzalgm\",\"dataupjhltyl\"],\"folder\":{\"name\":\"dvbgvzlzjs\"},\"\":{\"ydpoknse\":\"datacutzaz\"}}")
+ "{\"type\":\"PhoenixObject\",\"typeProperties\":{\"tableName\":\"datantbfytnhdnihu\",\"table\":\"datajuzvwgbzdtorbi\",\"schema\":\"datayfzdp\"},\"description\":\"tsucrxdtejobjz\",\"structure\":\"datawtidcnzalgmpupj\",\"schema\":\"datatyl\",\"linkedServiceName\":{\"referenceName\":\"uudvbgvzlzjsb\",\"parameters\":{\"mbdqra\":\"datautzaziydpoknsea\",\"o\":\"datakdarl\"}},\"parameters\":{\"vclfjyclvi\":{\"type\":\"Int\",\"defaultValue\":\"dataqwzknyujxy\"},\"pfildcg\":{\"type\":\"Array\",\"defaultValue\":\"datafflleirmtxf\"},\"cryvidbzdylbvj\":{\"type\":\"Float\",\"defaultValue\":\"datauzfbp\"}},\"annotations\":[\"datangw\",\"dataxjftecgprz\"],\"folder\":{\"name\":\"pdqcakzbyqhaathx\"},\"\":{\"lhrvmgsbpgmncr\":\"datauucolusyruxrzh\"}}")
.toObject(PhoenixObjectDataset.class);
- Assertions.assertEquals("otiixkkbygbgiq", model.description());
- Assertions.assertEquals("fzhzzcarciuo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("fscl").type());
- Assertions.assertEquals("dvbgvzlzjs", model.folder().name());
+ Assertions.assertEquals("tsucrxdtejobjz", model.description());
+ Assertions.assertEquals("uudvbgvzlzjsb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("vclfjyclvi").type());
+ Assertions.assertEquals("pdqcakzbyqhaathx", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PhoenixObjectDataset model = new PhoenixObjectDataset().withDescription("otiixkkbygbgiq")
- .withStructure("datayshybb")
- .withSchema("datattyizonzsurqcoja")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("fzhzzcarciuo")
- .withParameters(mapOf("hwsgnsputfe", "datapdthjfv", "hnu", "dataf", "chxxc", "datassjgbfbb",
- "bphceeivkbuxlep", "datazunf")))
- .withParameters(mapOf("fscl",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataqhqpvtwt"),
- "bfytnhdnihuzzjuz",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datagygn"),
- "tsucrxdtejobjz",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("databzdtorbiwnyfzdpx")))
- .withAnnotations(Arrays.asList("datat", "datad", "datanzalgm", "dataupjhltyl"))
- .withFolder(new DatasetFolder().withName("dvbgvzlzjs"))
- .withTableName("datadmupbusxyug")
- .withTable("datawplx")
- .withSchemaTypePropertiesSchema("datazu");
+ PhoenixObjectDataset model = new PhoenixObjectDataset().withDescription("tsucrxdtejobjz")
+ .withStructure("datawtidcnzalgmpupj")
+ .withSchema("datatyl")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("uudvbgvzlzjsb")
+ .withParameters(mapOf("mbdqra", "datautzaziydpoknsea", "o", "datakdarl")))
+ .withParameters(mapOf("vclfjyclvi",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataqwzknyujxy"), "pfildcg",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datafflleirmtxf"),
+ "cryvidbzdylbvj",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datauzfbp")))
+ .withAnnotations(Arrays.asList("datangw", "dataxjftecgprz"))
+ .withFolder(new DatasetFolder().withName("pdqcakzbyqhaathx"))
+ .withTableName("datantbfytnhdnihu")
+ .withTable("datajuzvwgbzdtorbi")
+ .withSchemaTypePropertiesSchema("datayfzdp");
model = BinaryData.fromObject(model).toObject(PhoenixObjectDataset.class);
- Assertions.assertEquals("otiixkkbygbgiq", model.description());
- Assertions.assertEquals("fzhzzcarciuo", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("fscl").type());
- Assertions.assertEquals("dvbgvzlzjs", model.folder().name());
+ Assertions.assertEquals("tsucrxdtejobjz", model.description());
+ Assertions.assertEquals("uudvbgvzlzjsb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("vclfjyclvi").type());
+ Assertions.assertEquals("pdqcakzbyqhaathx", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixSourceTests.java
index b70f6b492be8..bb2015b9ade3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PhoenixSourceTests.java
@@ -11,19 +11,19 @@ public final class PhoenixSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PhoenixSource model = BinaryData.fromString(
- "{\"type\":\"PhoenixSource\",\"query\":\"datajjprd\",\"queryTimeout\":\"datablonlhtgexwjhicu\",\"additionalColumns\":\"dataavimxnhylwogtvl\",\"sourceRetryCount\":\"datagd\",\"sourceRetryWait\":\"datat\",\"maxConcurrentConnections\":\"datadxlfn\",\"disableMetricsCollection\":\"dataclkmggnzlfyxaiaf\",\"\":{\"uoayapzzcxkuusba\":\"dataxekfvycvhw\",\"yak\":\"datacassqeybdnz\",\"zkicxtumqinawct\":\"datarkohfqm\",\"kjnpe\":\"dataarboxaluoadmcv\"}}")
+ "{\"type\":\"PhoenixSource\",\"query\":\"datav\",\"queryTimeout\":\"datapdv\",\"additionalColumns\":\"datayelrteunkwypu\",\"sourceRetryCount\":\"datafmsygt\",\"sourceRetryWait\":\"dataqlfdml\",\"maxConcurrentConnections\":\"datazdbrw\",\"disableMetricsCollection\":\"datawft\",\"\":{\"jsfgkwrcbgxypr\":\"dataxwi\",\"izabjb\":\"databpywecz\"}}")
.toObject(PhoenixSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PhoenixSource model = new PhoenixSource().withSourceRetryCount("datagd")
- .withSourceRetryWait("datat")
- .withMaxConcurrentConnections("datadxlfn")
- .withDisableMetricsCollection("dataclkmggnzlfyxaiaf")
- .withQueryTimeout("datablonlhtgexwjhicu")
- .withAdditionalColumns("dataavimxnhylwogtvl")
- .withQuery("datajjprd");
+ PhoenixSource model = new PhoenixSource().withSourceRetryCount("datafmsygt")
+ .withSourceRetryWait("dataqlfdml")
+ .withMaxConcurrentConnections("datazdbrw")
+ .withDisableMetricsCollection("datawft")
+ .withQueryTimeout("datapdv")
+ .withAdditionalColumns("datayelrteunkwypu")
+ .withQuery("datav");
model = BinaryData.fromObject(model).toObject(PhoenixSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineExternalComputeScalePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineExternalComputeScalePropertiesTests.java
index b70b7790189d..a74bc9fda969 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineExternalComputeScalePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineExternalComputeScalePropertiesTests.java
@@ -14,24 +14,24 @@ public final class PipelineExternalComputeScalePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PipelineExternalComputeScaleProperties model = BinaryData.fromString(
- "{\"timeToLive\":1301475128,\"numberOfPipelineNodes\":505679667,\"numberOfExternalNodes\":2049209439,\"\":{\"pdj\":\"dataquajpo\",\"raxhntoiwfszkr\":\"datayotg\",\"etsluqfgk\":\"datakosjwr\",\"imioixviobuwbnge\":\"datad\"}}")
+ "{\"timeToLive\":1001059770,\"numberOfPipelineNodes\":1054291035,\"numberOfExternalNodes\":1861848330,\"\":{\"pjfkr\":\"dataohvia\",\"wwdocjasu\":\"datarerdlgbvtpxowg\",\"exumfavweslo\":\"datamegjkfisz\",\"scosanjsoutrz\":\"datalitxrrs\"}}")
.toObject(PipelineExternalComputeScaleProperties.class);
- Assertions.assertEquals(1301475128, model.timeToLive());
- Assertions.assertEquals(505679667, model.numberOfPipelineNodes());
- Assertions.assertEquals(2049209439, model.numberOfExternalNodes());
+ Assertions.assertEquals(1001059770, model.timeToLive());
+ Assertions.assertEquals(1054291035, model.numberOfPipelineNodes());
+ Assertions.assertEquals(1861848330, model.numberOfExternalNodes());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
PipelineExternalComputeScaleProperties model
- = new PipelineExternalComputeScaleProperties().withTimeToLive(1301475128)
- .withNumberOfPipelineNodes(505679667)
- .withNumberOfExternalNodes(2049209439)
+ = new PipelineExternalComputeScaleProperties().withTimeToLive(1001059770)
+ .withNumberOfPipelineNodes(1054291035)
+ .withNumberOfExternalNodes(1861848330)
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(PipelineExternalComputeScaleProperties.class);
- Assertions.assertEquals(1301475128, model.timeToLive());
- Assertions.assertEquals(505679667, model.numberOfPipelineNodes());
- Assertions.assertEquals(2049209439, model.numberOfExternalNodes());
+ Assertions.assertEquals(1001059770, model.timeToLive());
+ Assertions.assertEquals(1054291035, model.numberOfPipelineNodes());
+ Assertions.assertEquals(1861848330, model.numberOfExternalNodes());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsCancelWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsCancelWithResponseMockTests.java
index 8b55e9faebdc..788f2070cfdf 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsCancelWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsCancelWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testCancelWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.pipelineRuns()
- .cancelWithResponse("wvamymswfw", "kucsop", "fhqxhtcohrhw", true, com.azure.core.util.Context.NONE);
+ .cancelWithResponse("uv", "uweqbeygnetuvs", "vgjvumdznblkofd", false, com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsGetWithResponseMockTests.java
index e79da540a3cc..b562475110d1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelineRunsGetWithResponseMockTests.java
@@ -20,7 +20,7 @@ public final class PipelineRunsGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"runId\":\"mrfjjrp\",\"runGroupId\":\"jecqwdosbsngyia\",\"isLatest\":false,\"pipelineName\":\"vlkuucpw\",\"parameters\":{\"c\":\"yrblrqeqcdi\",\"njxi\":\"cvzdtft\"},\"runDimensions\":{\"yixgxtccmqzkuq\":\"mm\",\"gindlnteoapszxq\":\"rzu\"},\"invokedBy\":{\"name\":\"vyracqmfjihm\",\"id\":\"zwoijtlhxlsxxra\",\"invokedByType\":\"aicgqgafkrtsaeag\",\"pipelineName\":\"ctcrdfxqhn\",\"pipelineRunId\":\"ujrnfdqlzggvo\"},\"lastUpdated\":\"2021-11-15T19:48:05Z\",\"runStart\":\"2021-08-31T03:56:26Z\",\"runEnd\":\"2021-10-30T14:33:10Z\",\"durationInMs\":41436935,\"status\":\"uj\",\"message\":\"jqci\",\"\":{\"shmntlbfknxzc\":\"datapsvgupqw\",\"ccpbtvgiokz\":\"datauvjbfryortbres\",\"dwawomkzussgjmub\":\"datatpvs\",\"ekzcmfibbozkp\":\"datagjdluwbmwuj\"}}";
+ = "{\"runId\":\"wzm\",\"runGroupId\":\"plzbzcgzhdrv\",\"isLatest\":false,\"pipelineName\":\"hfogjoocnseo\",\"parameters\":{\"zglgx\":\"tqrvzaabeiqopj\",\"hbieeswb\":\"qdlwuzkz\",\"otsawapm\":\"bijtepr\",\"bwy\":\"yfgswpqunvxtv\"},\"runDimensions\":{\"zwkzedi\":\"qpqyjebgveu\",\"ohz\":\"wdrrgzguupwq\",\"nco\":\"fbb\",\"jshyyrcr\":\"iniadlx\"},\"invokedBy\":{\"name\":\"qsfaurmqpkgwf\",\"id\":\"t\",\"invokedByType\":\"hmrhhx\",\"pipelineName\":\"bdnpeamslv\",\"pipelineRunId\":\"sywnifvwrdya\"},\"lastUpdated\":\"2021-01-05T09:04:18Z\",\"runStart\":\"2021-05-21T20:59:20Z\",\"runEnd\":\"2021-04-22T06:44:56Z\",\"durationInMs\":1046273347,\"status\":\"vvebxgxgr\",\"message\":\"oabhkyaspc\",\"\":{\"yxlcgycvcspcfx\":\"dataevjndvafxcvn\",\"ioqtafmbxtn\":\"dataal\",\"y\":\"datax\",\"a\":\"datarut\"}}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -30,7 +30,7 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PipelineRun response = manager.pipelineRuns()
- .getWithResponse("llzbtq", "jmio", "csdfbki", com.azure.core.util.Context.NONE)
+ .getWithResponse("kpsw", "sveymd", "bmffcryyykwwhscu", com.azure.core.util.Context.NONE)
.getValue();
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateOrUpdateWithResponseMockTests.java
index 9b7c61d55b94..bdb0c1d39cf5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateOrUpdateWithResponseMockTests.java
@@ -36,7 +36,7 @@ public final class PipelinesCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"description\":\"okft\",\"activities\":[{\"type\":\"Activity\",\"name\":\"ezplnzvrhg\",\"description\":\"eelkv\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"kwgsqosrpcxw\",\"dependencyConditions\":[]},{\"activity\":\"hkljktujf\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"qfryketwrzx\",\"value\":\"datamiy\"},{\"name\":\"fkgmyq\",\"value\":\"datajfjypp\"},{\"name\":\"xfubkf\",\"value\":\"datatvlwyety\"},{\"name\":\"nhispacivanl\",\"value\":\"datapspnjlopoang\"}],\"\":{\"tbm\":\"dataaixrbwbkrsmkeiun\",\"fc\":\"datadzfoxdtzzmcrmh\",\"b\":\"dataizxuiyuzufdm\"}},{\"type\":\"Activity\",\"name\":\"ygnfljvra\",\"description\":\"oecozfauhnxxdyah\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"k\",\"dependencyConditions\":[]},{\"activity\":\"mhax\",\"dependencyConditions\":[]},{\"activity\":\"wjimlfrk\",\"dependencyConditions\":[]},{\"activity\":\"ynmm\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"bxoe\",\"value\":\"datahordcc\"},{\"name\":\"kr\",\"value\":\"datazczlvql\"},{\"name\":\"ca\",\"value\":\"dataphsarty\"},{\"name\":\"qqwdgyshpvv\",\"value\":\"datagvqrwrchwdx\"}],\"\":{\"fjjxoxweuoklwt\":\"dataqq\"}},{\"type\":\"Activity\",\"name\":\"e\",\"description\":\"ndheocjc\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"wu\",\"dependencyConditions\":[]},{\"activity\":\"verplhfwqdvdqcoh\",\"dependencyConditions\":[]},{\"activity\":\"wzy\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"lt\",\"value\":\"datambhlhyqgfim\"},{\"name\":\"lr\",\"value\":\"datadqwpudvup\"},{\"name\":\"izztkl\",\"value\":\"datashdeehtjmdefkphs\"},{\"name\":\"kivyaf\",\"value\":\"datapcnnpjulpwwmxwl\"}],\"\":{\"zjazepbjukikd\":\"datarkf\",\"unsvsjo\":\"datavruxmpnugujiwi\",\"lt\":\"dataanxs\"}}],\"parameters\":{\"enpybuskvjb\":{\"type\":\"Int\",\"defaultValue\":\"dataqxruqrobk\"},\"kkgawnaeoeuidh\":{\"type\":\"Bool\",\"defaultValue\":\"dataqudxvjrndbinqq\"}},\"variables\":{\"xeclwl\":{\"type\":\"String\",\"defaultValue\":\"dataitnzpfdoetetisk\"},\"nfmxomupdqpcxiv\":{\"type\":\"Array\",\"defaultValue\":\"datar\"}},\"concurrency\":920981998,\"annotations\":[\"datamefjpoellyvbvxl\",\"dataltrztr\",\"dataoyrjvrxyrxhfrsyc\"],\"runDimensions\":{\"hlnbawffrzgeobz\":\"dataefmqhtrzlvfncp\",\"grojpnxz\":\"dataxzraihl\",\"yysycey\":\"datarc\"},\"folder\":{\"name\":\"lxhymc\"},\"policy\":{\"elapsedTimeMetric\":{\"duration\":\"datapymroyygt\"}}},\"name\":\"mpwzlbqdxvxdfkdw\",\"type\":\"mnoecfjw\",\"etag\":\"iupgmdszwrfdj\",\"\":{\"qfi\":\"datajsmdrecrrbkm\"},\"id\":\"goapxdmxwetkj\"}";
+ = "{\"properties\":{\"description\":\"srysgab\",\"activities\":[{\"type\":\"Activity\",\"name\":\"pvadyxjcckhgstoh\",\"description\":\"rqbzlmvw\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"qumpspo\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"pnyzytgkdwvt\",\"value\":\"datamvqliqzf\"},{\"name\":\"lprljilpuav\",\"value\":\"dataidytjmkfx\"},{\"name\":\"go\",\"value\":\"datackmmagfbreyvr\"}],\"\":{\"urlywxjvs\":\"dataikwqtlgfry\",\"qmikljczxotblx\":\"datazchysqypt\"}},{\"type\":\"Activity\",\"name\":\"pqfxyywsxrxv\",\"description\":\"wkzaqqkqyijy\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"qiqzmgx\",\"dependencyConditions\":[]},{\"activity\":\"nldbkuqc\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"wzqnbjkstvbmfnj\",\"value\":\"dataz\"}],\"\":{\"agehqghxj\":\"dataowyyy\",\"xpaytzqgsaegaahw\":\"dataiggcaimk\",\"hgrgiu\":\"dataerd\"}}],\"parameters\":{\"brdamdnebko\":{\"type\":\"Bool\",\"defaultValue\":\"datavoskji\"},\"hepjs\":{\"type\":\"String\",\"defaultValue\":\"dataknmza\"},\"bw\":{\"type\":\"Bool\",\"defaultValue\":\"datauhhfohsp\"},\"djsakigrlmiglnqr\":{\"type\":\"Int\",\"defaultValue\":\"datalavuecmdmcor\"}},\"variables\":{\"di\":{\"type\":\"Array\",\"defaultValue\":\"dataquwsfebhvkk\"},\"yotejljdrerzjwex\":{\"type\":\"String\",\"defaultValue\":\"datalioagvijr\"},\"dcxf\":{\"type\":\"String\",\"defaultValue\":\"dataxbeufzb\"}},\"concurrency\":886481924,\"annotations\":[\"datazme\",\"datacjsneybpqot\",\"datadb\",\"dataljs\"],\"runDimensions\":{\"lauupwt\":\"datauptre\",\"ab\":\"datatpbi\",\"kxbgfed\":\"dataegcogyctekaaju\"},\"folder\":{\"name\":\"jsyors\"},\"policy\":{\"elapsedTimeMetric\":{\"duration\":\"datatqragq\"}}},\"name\":\"ouxspkxapqgyh\",\"type\":\"qkkwzbgbwwop\",\"etag\":\"dwsekr\",\"\":{\"btztwvhgkmxarqt\":\"datalqstmi\",\"oxdwox\":\"datazeo\",\"bswfjrtxf\":\"datanqt\",\"flbaxywojtryrd\":\"datahaqpmlyzwgotl\"},\"id\":\"gt\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -46,105 +46,76 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PipelineResource response = manager.pipelines()
- .define("amnxzduyd")
- .withExistingFactory("bhuai", "dxquow")
- .withDescription("vwoclmdcoqwdmegk")
+ .define("brkrfvlqwije")
+ .withExistingFactory("fhqxhtcohrhw", "vvomcjpjrxvsgga")
+ .withDescription("npihtgigaeeqg")
.withActivities(Arrays.asList(
- new Activity().withName("uguvnwcvlmyrw")
- .withDescription("rtubemptxm")
+ new Activity().withName("rozlfccpgeqix")
+ .withDescription("gltqld")
.withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("mmwpqcdmfrjqfe")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("gdkxiprrvfy")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("vkmom")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("evqbcdjlnnvhb").withValue("datajutupgmmtit"),
- new UserProperty().withName("poqqakpbkwqavxlj").withValue("dataybgxxm"),
- new UserProperty().withName("drgxhrtans").withValue("databoiyqi")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("gdgfjvitdp")
- .withDescription("oesx")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("caspwvglaxvn")
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("ld")
.withDependencyConditions(Arrays.asList())
.withAdditionalProperties(mapOf())))
.withUserProperties(
- Arrays.asList(new UserProperty().withName("atwxqaggbirzj").withValue("dataaicyuplmdhuu"),
- new UserProperty().withName("tiecnpka").withValue("datatjqjtoeaug"),
- new UserProperty().withName("osrywpfcqle").withValue("dataiafsizdec")))
+ Arrays.asList(new UserProperty().withName("cajhnnbp").withValue("datanogyvpfyjlfnjmwb"),
+ new UserProperty().withName("oqhy").withValue("datarpwkvz"),
+ new UserProperty().withName("bvdlhcyoykmp").withValue("datatfc"),
+ new UserProperty().withName("ugitjnwajqzig").withValue("datafea")))
.withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("qgf")
- .withDescription("trvvhxjfkpu")
- .withState(ActivityState.ACTIVE)
+ new Activity().withName("edaqpquzcvmrux")
+ .withDescription("slausvbvtctiso")
+ .withState(ActivityState.INACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("l")
+ new ActivityDependency().withActivity("bacmnjzjjrhvd")
.withDependencyConditions(Arrays.asList())
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("xwnircmodws")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("hzlamdqgav")
+ new ActivityDependency().withActivity("fstmbbjil")
.withDependencyConditions(Arrays.asList())
.withAdditionalProperties(mapOf())))
.withUserProperties(
- Arrays.asList(new UserProperty().withName("wkjambfsxsr").withValue("datajfapiodsn"),
- new UserProperty().withName("yezwjqb").withValue("datacxlg"),
- new UserProperty().withName("uxo").withValue("datamjxqintjhvcoro")))
+ Arrays.asList(new UserProperty().withName("ctykc").withValue("dataksvflurrfnlhlfv"),
+ new UserProperty().withName("rohyecblvpwu").withValue("dataqvmfuuhm")))
.withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("mefsxmdmlowe")
- .withDescription("xpwfvtwgnm")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("omjsfkdvbhc")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("hinjnwpiv")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("baj").withValue("dataec"),
- new UserProperty().withName("gwkzu").withValue("dataxsrmadakjsypuvyv"),
- new UserProperty().withName("bkkekldxclqjn").withValue("datahotwq")))
+ new Activity().withName("mgvipzvvrfplkemv")
+ .withDescription("gezy")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("wplyv")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("pemcf").withValue("dataxkifjvil"),
+ new UserProperty().withName("zopwud").withValue("dataew"),
+ new UserProperty().withName("xaufowhmd").withValue("dataggakt")))
.withAdditionalProperties(mapOf("type", "Activity"))))
- .withParameters(mapOf("yrsravsscblsxms",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datahsfjqxlbclvpgbu"),
- "ixwx",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datagdtuzclfbvvuyoil"),
- "xs", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datauuvbbh"),
- "midvicdqufjahuc",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datalxwlmxzoibipktbl")))
- .withVariables(mapOf("trfdipss",
- new VariableSpecification().withType(VariableType.STRING).withDefaultValue("datacklthsuasnxdhlov")))
- .withConcurrency(1782839703)
- .withAnnotations(Arrays.asList("databydryysvex", "datazs", "databfnkj"))
- .withRunDimensions(mapOf("uah", "dataynpbirltz", "sdtysnlxw", "datalxcdpj"))
- .withFolder(new PipelineFolder().withName("ez"))
+ .withParameters(mapOf("ftdfmzlgjcepx",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataaddmji"), "wyclehagb",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datawvpavutis"),
+ "mpzamq", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataet")))
+ .withVariables(mapOf("hmwxhvspumokm",
+ new VariableSpecification().withType(VariableType.BOOL).withDefaultValue("datayyphtd")))
+ .withConcurrency(1435502173)
+ .withAnnotations(Arrays.asList("datatpvebxesuc", "dataynsqxyowwrb", "dataej"))
+ .withRunDimensions(mapOf("sw", "datarshl"))
+ .withFolder(new PipelineFolder().withName("rusxyugidk"))
.withPolicy(new PipelinePolicy()
- .withElapsedTimeMetric(new PipelineElapsedTimeMetricPolicy().withDuration("datajjzcxtzkoloosc")))
- .withIfMatch("ezapuun")
+ .withElapsedTimeMetric(new PipelineElapsedTimeMetricPolicy().withDuration("datavdtrtkqqd")))
+ .withIfMatch("kmdaihgiglk")
.create();
- Assertions.assertEquals("goapxdmxwetkj", response.id());
- Assertions.assertEquals("okft", response.description());
- Assertions.assertEquals("ezplnzvrhg", response.activities().get(0).name());
- Assertions.assertEquals("eelkv", response.activities().get(0).description());
- Assertions.assertEquals(ActivityState.ACTIVE, response.activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, response.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("kwgsqosrpcxw", response.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals("qfryketwrzx", response.activities().get(0).userProperties().get(0).name());
- Assertions.assertEquals(ParameterType.INT, response.parameters().get("enpybuskvjb").type());
- Assertions.assertEquals(VariableType.STRING, response.variables().get("xeclwl").type());
- Assertions.assertEquals(920981998, response.concurrency());
- Assertions.assertEquals("lxhymc", response.folder().name());
+ Assertions.assertEquals("gt", response.id());
+ Assertions.assertEquals("srysgab", response.description());
+ Assertions.assertEquals("pvadyxjcckhgstoh", response.activities().get(0).name());
+ Assertions.assertEquals("rqbzlmvw", response.activities().get(0).description());
+ Assertions.assertEquals(ActivityState.INACTIVE, response.activities().get(0).state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, response.activities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("qumpspo", response.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("pnyzytgkdwvt", response.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals(ParameterType.BOOL, response.parameters().get("brdamdnebko").type());
+ Assertions.assertEquals(VariableType.ARRAY, response.variables().get("di").type());
+ Assertions.assertEquals(886481924, response.concurrency());
+ Assertions.assertEquals("jsyors", response.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateRunWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateRunWithResponseMockTests.java
index cf3b8ec158af..ad45d274fc47 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateRunWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesCreateRunWithResponseMockTests.java
@@ -22,7 +22,7 @@
public final class PipelinesCreateRunWithResponseMockTests {
@Test
public void testCreateRunWithResponse() throws Exception {
- String responseStr = "{\"runId\":\"pxdnkgrxhpx\"}";
+ String responseStr = "{\"runId\":\"ucsop\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,11 +32,13 @@ public void testCreateRunWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
CreateRunResponse response = manager.pipelines()
- .createRunWithResponse("icznotggy", "nssghafzdzdf", "udmiutzuriqlksba", "yxtiqzjrxh", false, "qheqzdxda",
- false, mapOf("wjzqmbe", "dataetgymd"), com.azure.core.util.Context.NONE)
+ .createRunWithResponse("xiiumrdbqujyij", "ciaznpsvgupqwqs", "mntlbfknxzc", "uvjbfryortbres", true,
+ "cpbtvgiokz", false,
+ mapOf("ubggjdluwbmwu", "datavswdwawomkzussgj", "ptwvamymswfwc", "databekzcmfibboz"),
+ com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("pxdnkgrxhpx", response.runId());
+ Assertions.assertEquals("ucsop", response.runId());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesDeleteWithResponseMockTests.java
index cc4b598b0f50..515775e6f061 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesDeleteWithResponseMockTests.java
@@ -27,7 +27,8 @@ public void testDeleteWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.pipelines().deleteWithResponse("rtcacdomz", "whjthoxl", "tya", com.azure.core.util.Context.NONE);
+ manager.pipelines()
+ .deleteWithResponse("fkrtsaeagvqctcrd", "xqhnw", "ujrnfdqlzggvo", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesGetWithResponseMockTests.java
index 1068e07c92ff..a6c181659804 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesGetWithResponseMockTests.java
@@ -25,7 +25,7 @@ public final class PipelinesGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"description\":\"sanchrou\",\"activities\":[{\"type\":\"Activity\",\"name\":\"ptdeumlfszxqrabk\",\"description\":\"eodgpqdcrn\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"htuiws\",\"dependencyConditions\":[]},{\"activity\":\"ccmun\",\"dependencyConditions\":[]},{\"activity\":\"vw\",\"dependencyConditions\":[]},{\"activity\":\"sgczvuiprngne\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"zdayzfu\",\"value\":\"databnelmi\"},{\"name\":\"mccevbpr\",\"value\":\"datacgeregft\"},{\"name\":\"gjmznptevafczg\",\"value\":\"datase\"}],\"\":{\"wg\":\"dataiynlcdqxownbj\",\"gcfjnoz\":\"datagowkazmwrxsfejkr\",\"htg\":\"datatyqqoswk\"}},{\"type\":\"Activity\",\"name\":\"ewflxbyyvaufx\",\"description\":\"s\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"ndocqaptw\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"smonwhazalftta\",\"value\":\"dataz\"},{\"name\":\"sve\",\"value\":\"datasrduqhrlltfec\"},{\"name\":\"xzhbfibzvxqh\",\"value\":\"datapjdbz\"},{\"name\":\"lchv\",\"value\":\"datasydjr\"}],\"\":{\"ohppupucybtr\":\"dataawfujvgvrpear\"}},{\"type\":\"Activity\",\"name\":\"velcbm\",\"description\":\"hogxexeaexw\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"zmqdnfonncnf\",\"dependencyConditions\":[]},{\"activity\":\"yggiomgv\",\"dependencyConditions\":[]},{\"activity\":\"arx\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"mjygnixkpadjqjwl\",\"value\":\"dataqeibucmfvuizjrs\"},{\"name\":\"n\",\"value\":\"datamaezxldmzh\"},{\"name\":\"uzwy\",\"value\":\"datasvgonkomuapyskw\"},{\"name\":\"ytgf\",\"value\":\"datavulesqjdbcypv\"}],\"\":{\"gafhbfp\":\"datafyqsf\",\"slmyrsojqpjba\":\"datafvqlmzpckxl\",\"dfulvm\":\"datafnxdi\",\"phdhtcopz\":\"dataalvcahy\"}},{\"type\":\"Activity\",\"name\":\"cexbtwicghxmeig\",\"description\":\"mmkwazkuemo\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"xmwq\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"vzczisiqnsiv\",\"value\":\"datajfu\"},{\"name\":\"qbatdnufvzxosrst\",\"value\":\"datavdtssa\"}],\"\":{\"pjslrfpxlutfbhs\":\"datadojimfaa\"}}],\"parameters\":{\"vcvutar\":{\"type\":\"Int\",\"defaultValue\":\"databxtabxdkboyqes\"},\"ikqz\":{\"type\":\"Object\",\"defaultValue\":\"datajppmil\"}},\"variables\":{\"ipj\":{\"type\":\"Array\",\"defaultValue\":\"datacqdnzhjlbdlhnk\"},\"r\":{\"type\":\"String\",\"defaultValue\":\"dataikxocfmkcnjzxezo\"},\"xyc\":{\"type\":\"String\",\"defaultValue\":\"datawthslztxixngwe\"}},\"concurrency\":97669330,\"annotations\":[\"datadf\",\"dataqnbco\"],\"runDimensions\":{\"prgxdcnbzp\":\"datascfbwkhleumib\",\"pzekm\":\"dataxoqum\",\"qnttmhs\":\"datapdvnanxrkwzlaomt\",\"cxyfje\":\"datawq\"},\"folder\":{\"name\":\"gelipoequjk\"},\"policy\":{\"elapsedTimeMetric\":{\"duration\":\"datarxxcbptvvwf\"}}},\"name\":\"hljhinmh\",\"type\":\"wmrckvl\",\"etag\":\"zwd\",\"\":{\"xmzpf\":\"databsrjofxoktokmsyo\",\"dkbndkofrhuycn\":\"datattcmwqrbtad\",\"wxfkgzgveudmidt\":\"datayhodtugrw\"},\"id\":\"q\"}";
+ = "{\"properties\":{\"description\":\"xweuoklwtoecxndh\",\"activities\":[{\"type\":\"Activity\",\"name\":\"jcjocunanwutv\",\"description\":\"plhfwqdvd\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"ynbhltrmbhlhyqgf\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"lr\",\"value\":\"datadqwpudvup\"},{\"name\":\"izztkl\",\"value\":\"datashdeehtjmdefkphs\"}],\"\":{\"opcnnpjulpw\":\"datavya\"}},{\"type\":\"Activity\",\"name\":\"mxwlwcurkfxzja\",\"description\":\"pbju\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"uxmpnugujiw\",\"dependencyConditions\":[]},{\"activity\":\"duns\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"obanxshltfghy\",\"value\":\"dataqxruqrobk\"},{\"name\":\"enpybuskvjb\",\"value\":\"datagkqudxvj\"},{\"name\":\"ndbinqqrkkgawn\",\"value\":\"dataeoeui\"}],\"\":{\"iskqxeclw\":\"datavaxyitnzpfdoete\",\"r\":\"dataso\"}},{\"type\":\"Activity\",\"name\":\"nfmxomupdqpcxiv\",\"description\":\"dvwmefjpoell\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"ltrztr\",\"dependencyConditions\":[]},{\"activity\":\"oyrjvrxyrxhfrsyc\",\"dependencyConditions\":[]},{\"activity\":\"qwefmqhtrzlvf\",\"dependencyConditions\":[]},{\"activity\":\"cphh\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"awffrzgeobz\",\"value\":\"dataxzraihl\"}],\"\":{\"syceykvmlxhym\":\"dataojpnxzjrccy\"}}],\"parameters\":{\"tmpwzlb\":{\"type\":\"Bool\",\"defaultValue\":\"datapymroyygt\"},\"cfjw\":{\"type\":\"Bool\",\"defaultValue\":\"datavxdfkdwkhmno\"}},\"variables\":{\"zwrfdjx\":{\"type\":\"Array\",\"defaultValue\":\"datagmd\"},\"fisggoapxdmxwet\":{\"type\":\"Bool\",\"defaultValue\":\"datasmdrecrrbkmz\"},\"ctdxargqff\":{\"type\":\"String\",\"defaultValue\":\"dataxekql\"},\"lzbtqzjmi\":{\"type\":\"Bool\",\"defaultValue\":\"datafbfqw\"}},\"concurrency\":1818860634,\"annotations\":[\"dataf\"],\"runDimensions\":{\"ptsjecqwdosbsng\":\"datawumrfjj\"},\"folder\":{\"name\":\"cwdxvlk\"},\"policy\":{\"elapsedTimeMetric\":{\"duration\":\"datawrgr\"}}},\"name\":\"blrqeqcdikcqc\",\"type\":\"dtfthnjxid\",\"etag\":\"mm\",\"\":{\"kuqrrzuegin\":\"dataxgxtccmq\",\"racqmfji\":\"datalnteoapszxqnjxv\",\"oijtlhxlsxx\":\"datamcgz\"},\"id\":\"fgaicgqg\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -35,20 +35,20 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PipelineResource response = manager.pipelines()
- .getWithResponse("oxjqysfejddi", "gwckvoxlih", "gafznzemis", "unx", com.azure.core.util.Context.NONE)
+ .getWithResponse("iqq", "dgyshpvva", "vq", "wrchwdxdkvqqtfjj", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("q", response.id());
- Assertions.assertEquals("sanchrou", response.description());
- Assertions.assertEquals("ptdeumlfszxqrabk", response.activities().get(0).name());
- Assertions.assertEquals("eodgpqdcrn", response.activities().get(0).description());
+ Assertions.assertEquals("fgaicgqg", response.id());
+ Assertions.assertEquals("xweuoklwtoecxndh", response.description());
+ Assertions.assertEquals("jcjocunanwutv", response.activities().get(0).name());
+ Assertions.assertEquals("plhfwqdvd", response.activities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, response.activities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, response.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("htuiws", response.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals("zdayzfu", response.activities().get(0).userProperties().get(0).name());
- Assertions.assertEquals(ParameterType.INT, response.parameters().get("vcvutar").type());
- Assertions.assertEquals(VariableType.ARRAY, response.variables().get("ipj").type());
- Assertions.assertEquals(97669330, response.concurrency());
- Assertions.assertEquals("gelipoequjk", response.folder().name());
+ Assertions.assertEquals("ynbhltrmbhlhyqgf", response.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("lr", response.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals(ParameterType.BOOL, response.parameters().get("tmpwzlb").type());
+ Assertions.assertEquals(VariableType.ARRAY, response.variables().get("zwrfdjx").type());
+ Assertions.assertEquals(1818860634, response.concurrency());
+ Assertions.assertEquals("cwdxvlk", response.folder().name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesListByFactoryMockTests.java
index 213794f2d89b..dc3709bdc182 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PipelinesListByFactoryMockTests.java
@@ -26,7 +26,7 @@ public final class PipelinesListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"description\":\"nqiighpxxw\",\"activities\":[{\"type\":\"Activity\",\"name\":\"mqugovcddxlrb\",\"description\":\"qrgjejabqvg\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"pxlyabjrzgssjf\",\"dependencyConditions\":[]},{\"activity\":\"urhku\",\"dependencyConditions\":[]},{\"activity\":\"phbwmbgwgmyglnsn\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"qdsygdzzufrj\",\"value\":\"datawqwdglmfsjplfd\"},{\"name\":\"zlt\",\"value\":\"dataywykfuovk\"}],\"\":{\"pgvxii\":\"datazghtjxtzywoq\"}}],\"parameters\":{\"lt\":{\"type\":\"Float\",\"defaultValue\":\"datakthxudowj\"},\"cohsqufsyihsnzsj\":{\"type\":\"SecureString\",\"defaultValue\":\"datazq\"},\"jzalhunbmngstvnk\":{\"type\":\"Array\",\"defaultValue\":\"dataogyake\"},\"yinxxgxncoai\":{\"type\":\"Object\",\"defaultValue\":\"dataulltvlylbo\"}},\"variables\":{\"taocxaku\":{\"type\":\"Array\",\"defaultValue\":\"datamdjz\"}},\"concurrency\":64653521,\"annotations\":[\"datahan\"],\"runDimensions\":{\"el\":\"dataojod\"},\"folder\":{\"name\":\"dxqlrwwm\"},\"policy\":{\"elapsedTimeMetric\":{\"duration\":\"datavgusfrkjfrtauf\"}}},\"name\":\"xvzqine\",\"type\":\"jodvkn\",\"etag\":\"tttkhm\",\"\":{\"vdqfkjg\":\"datacasfqodc\",\"plxbxfrl\":\"datalcfoaabltvltt\"},\"id\":\"ikcnlbehxo\"}]}";
+ = "{\"value\":[{\"properties\":{\"description\":\"gxsfeslxwlmx\",\"activities\":[{\"type\":\"Activity\",\"name\":\"bi\",\"description\":\"tblomidvicdquf\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"bdt\",\"dependencyConditions\":[]},{\"activity\":\"klths\",\"dependencyConditions\":[]},{\"activity\":\"asnxdhlovktrfdip\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"xxosbydryysv\",\"value\":\"dataxpzsx\"},{\"name\":\"fnkjjwtynp\",\"value\":\"datairltzyuahnl\"}],\"\":{\"zezfhfjjjzcxtz\":\"datapjssdtysnlxwq\",\"qhph\":\"dataoloosceukqi\",\"oqmxkxfmwbrvslfo\":\"dataqkkacw\"}}],\"parameters\":{\"uj\":{\"type\":\"Array\",\"defaultValue\":\"dataemzrpdnu\"},\"dqfynrdagmihxjpf\":{\"type\":\"SecureString\",\"defaultValue\":\"databgcloknh\"},\"frmqbmcmgezapu\":{\"type\":\"Int\",\"defaultValue\":\"datauibczlre\"},\"gjweelkviki\":{\"type\":\"Array\",\"defaultValue\":\"datayokftdlwezplnzvr\"}},\"variables\":{\"cxwthkljk\":{\"type\":\"Bool\",\"defaultValue\":\"datawgsqosr\"},\"qfryketwrzx\":{\"type\":\"Bool\",\"defaultValue\":\"datafcr\"},\"yqnjfjyppix\":{\"type\":\"Bool\",\"defaultValue\":\"datayifkg\"},\"sp\":{\"type\":\"Array\",\"defaultValue\":\"datakfjtvlwyetyrnh\"}},\"concurrency\":1297296760,\"annotations\":[\"datanlypspn\"],\"runDimensions\":{\"b\":\"datapoangrlmaixrb\",\"mkeiunxtbme\":\"datar\",\"hfcaiz\":\"datazfoxdtzzmcrm\",\"fljv\":\"datauiyuzufdmsbvyg\"},\"folder\":{\"name\":\"k\"},\"policy\":{\"elapsedTimeMetric\":{\"duration\":\"datazfauhnxxdyahlg\"}}},\"name\":\"cjpkzmhaxtwjimlf\",\"type\":\"mynmmmglbxoeghor\",\"etag\":\"cp\",\"\":{\"ca\":\"datazczlvql\"},\"id\":\"hsart\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -36,22 +36,21 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.pipelines().listByFactory("ho", "cchynnm", com.azure.core.util.Context.NONE);
+ = manager.pipelines().listByFactory("bvvuyoilnixwxw", "quuvb", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("ikcnlbehxo", response.iterator().next().id());
- Assertions.assertEquals("nqiighpxxw", response.iterator().next().description());
- Assertions.assertEquals("mqugovcddxlrb", response.iterator().next().activities().get(0).name());
- Assertions.assertEquals("qrgjejabqvg", response.iterator().next().activities().get(0).description());
+ Assertions.assertEquals("hsart", response.iterator().next().id());
+ Assertions.assertEquals("gxsfeslxwlmx", response.iterator().next().description());
+ Assertions.assertEquals("bi", response.iterator().next().activities().get(0).name());
+ Assertions.assertEquals("tblomidvicdquf", response.iterator().next().activities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, response.iterator().next().activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED,
response.iterator().next().activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("pxlyabjrzgssjf",
- response.iterator().next().activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals("qdsygdzzufrj",
+ Assertions.assertEquals("bdt", response.iterator().next().activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("xxosbydryysv",
response.iterator().next().activities().get(0).userProperties().get(0).name());
- Assertions.assertEquals(ParameterType.FLOAT, response.iterator().next().parameters().get("lt").type());
- Assertions.assertEquals(VariableType.ARRAY, response.iterator().next().variables().get("taocxaku").type());
- Assertions.assertEquals(64653521, response.iterator().next().concurrency());
- Assertions.assertEquals("dxqlrwwm", response.iterator().next().folder().name());
+ Assertions.assertEquals(ParameterType.ARRAY, response.iterator().next().parameters().get("uj").type());
+ Assertions.assertEquals(VariableType.BOOL, response.iterator().next().variables().get("cxwthkljk").type());
+ Assertions.assertEquals(1297296760, response.iterator().next().concurrency());
+ Assertions.assertEquals("k", response.iterator().next().folder().name());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PolybaseSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PolybaseSettingsTests.java
index 8bc8781ac520..9672a66497d5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PolybaseSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PolybaseSettingsTests.java
@@ -15,20 +15,20 @@ public final class PolybaseSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PolybaseSettings model = BinaryData.fromString(
- "{\"rejectType\":\"value\",\"rejectValue\":\"datadny\",\"rejectSampleValue\":\"dataol\",\"useTypeDefault\":\"dataekcpumckcbsa\",\"\":{\"dqilzogilgrqzwy\":\"datacssc\",\"qxe\":\"datawhfybflrpvcg\",\"fjkxxn\":\"datasghpsqvuisedeqr\"}}")
+ "{\"rejectType\":\"percentage\",\"rejectValue\":\"datafaekpxvetdrcmts\",\"rejectSampleValue\":\"datawt\",\"useTypeDefault\":\"datany\",\"\":{\"ekzy\":\"datarfvoskwujhskx\"}}")
.toObject(PolybaseSettings.class);
- Assertions.assertEquals(PolybaseSettingsRejectType.VALUE, model.rejectType());
+ Assertions.assertEquals(PolybaseSettingsRejectType.PERCENTAGE, model.rejectType());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PolybaseSettings model = new PolybaseSettings().withRejectType(PolybaseSettingsRejectType.VALUE)
- .withRejectValue("datadny")
- .withRejectSampleValue("dataol")
- .withUseTypeDefault("dataekcpumckcbsa")
+ PolybaseSettings model = new PolybaseSettings().withRejectType(PolybaseSettingsRejectType.PERCENTAGE)
+ .withRejectValue("datafaekpxvetdrcmts")
+ .withRejectSampleValue("datawt")
+ .withUseTypeDefault("datany")
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(PolybaseSettings.class);
- Assertions.assertEquals(PolybaseSettingsRejectType.VALUE, model.rejectType());
+ Assertions.assertEquals(PolybaseSettingsRejectType.PERCENTAGE, model.rejectType());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlSourceTests.java
index 00e463abeae0..0fe119f01c69 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlSourceTests.java
@@ -11,19 +11,19 @@ public final class PostgreSqlSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PostgreSqlSource model = BinaryData.fromString(
- "{\"type\":\"PostgreSqlSource\",\"query\":\"datayqdhaz\",\"queryTimeout\":\"dataug\",\"additionalColumns\":\"datasovo\",\"sourceRetryCount\":\"dataepkrncjrqhugu\",\"sourceRetryWait\":\"databqq\",\"maxConcurrentConnections\":\"datahcmvdowlqcyhfub\",\"disableMetricsCollection\":\"dataxqxxgrawbftznxfr\",\"\":{\"illjuco\":\"dataefiutbrn\",\"fim\":\"datarbkdieismdk\",\"lmn\":\"dataecij\"}}")
+ "{\"type\":\"PostgreSqlSource\",\"query\":\"datahjybboqyxi\",\"queryTimeout\":\"datadvdgemy\",\"additionalColumns\":\"dataddzjtxlvgslmgl\",\"sourceRetryCount\":\"dataeyvag\",\"sourceRetryWait\":\"datafqpaexlltme\",\"maxConcurrentConnections\":\"dataaeigrhrdn\",\"disableMetricsCollection\":\"datavsrtqltawjkra\",\"\":{\"sb\":\"datalpy\",\"x\":\"datanwiwru\",\"lhbrwaltvkyl\":\"datayr\"}}")
.toObject(PostgreSqlSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PostgreSqlSource model = new PostgreSqlSource().withSourceRetryCount("dataepkrncjrqhugu")
- .withSourceRetryWait("databqq")
- .withMaxConcurrentConnections("datahcmvdowlqcyhfub")
- .withDisableMetricsCollection("dataxqxxgrawbftznxfr")
- .withQueryTimeout("dataug")
- .withAdditionalColumns("datasovo")
- .withQuery("datayqdhaz");
+ PostgreSqlSource model = new PostgreSqlSource().withSourceRetryCount("dataeyvag")
+ .withSourceRetryWait("datafqpaexlltme")
+ .withMaxConcurrentConnections("dataaeigrhrdn")
+ .withDisableMetricsCollection("datavsrtqltawjkra")
+ .withQueryTimeout("datadvdgemy")
+ .withAdditionalColumns("dataddzjtxlvgslmgl")
+ .withQuery("datahjybboqyxi");
model = BinaryData.fromObject(model).toObject(PostgreSqlSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTests.java
index ea502035f102..4bc9cb620b56 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTests.java
@@ -19,35 +19,40 @@ public final class PostgreSqlTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PostgreSqlTableDataset model = BinaryData.fromString(
- "{\"type\":\"PostgreSqlTable\",\"typeProperties\":{\"tableName\":\"databgwzhbhflj\",\"table\":\"dataod\",\"schema\":\"dataovnlhrwya\"},\"description\":\"uafapwxsvdeatjio\",\"structure\":\"datairgoextqdn\",\"schema\":\"datagntimz\",\"linkedServiceName\":{\"referenceName\":\"upbmtbsetkods\",\"parameters\":{\"jyvdhdgdiwmlg\":\"dataedaakghcrzmm\",\"fkakhgkrvtyycvy\":\"datatmfetqjisjmolzca\",\"ejqaw\":\"datav\",\"pbbimh\":\"datausqpfzxkczbd\"}},\"parameters\":{\"zl\":{\"type\":\"Float\",\"defaultValue\":\"dataoortclnhbjcy\"},\"lkv\":{\"type\":\"SecureString\",\"defaultValue\":\"datascibv\"}},\"annotations\":[\"dataafnwqh\"],\"folder\":{\"name\":\"cnviulby\"},\"\":{\"umwhmxpuck\":\"datajzrycwpb\"}}")
+ "{\"type\":\"PostgreSqlTable\",\"typeProperties\":{\"tableName\":\"datansastl\",\"table\":\"datamgomicttrvlv\",\"schema\":\"datamxokxxamqecjrzvl\"},\"description\":\"vqxdemklphx\",\"structure\":\"datawlojkbgnfbrzj\",\"schema\":\"datasunhaevlah\",\"linkedServiceName\":{\"referenceName\":\"czywywuahwc\",\"parameters\":{\"jfdaj\":\"datawcnnaax\",\"omggew\":\"datafgi\",\"yznvussu\":\"dataqbxex\",\"xayzqbyeyw\":\"datakslws\"}},\"parameters\":{\"dzt\":{\"type\":\"String\",\"defaultValue\":\"datartlikff\"},\"dteqjmyqxuhg\":{\"type\":\"String\",\"defaultValue\":\"datafbgynzfwv\"},\"wrrlccklyf\":{\"type\":\"Array\",\"defaultValue\":\"datanyprijyoxxjxbs\"},\"apvibzi\":{\"type\":\"Array\",\"defaultValue\":\"dataspauemqomxoalknu\"}},\"annotations\":[\"dataichca\"],\"folder\":{\"name\":\"hjxnrkbnvfccklz\"},\"\":{\"pksywicklktgkdp\":\"datafgvlxyxmncti\",\"efuhb\":\"datatqjytdc\"}}")
.toObject(PostgreSqlTableDataset.class);
- Assertions.assertEquals("uafapwxsvdeatjio", model.description());
- Assertions.assertEquals("upbmtbsetkods", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("zl").type());
- Assertions.assertEquals("cnviulby", model.folder().name());
+ Assertions.assertEquals("vqxdemklphx", model.description());
+ Assertions.assertEquals("czywywuahwc", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("dzt").type());
+ Assertions.assertEquals("hjxnrkbnvfccklz", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PostgreSqlTableDataset model = new PostgreSqlTableDataset().withDescription("uafapwxsvdeatjio")
- .withStructure("datairgoextqdn")
- .withSchema("datagntimz")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("upbmtbsetkods")
- .withParameters(mapOf("jyvdhdgdiwmlg", "dataedaakghcrzmm", "fkakhgkrvtyycvy", "datatmfetqjisjmolzca",
- "ejqaw", "datav", "pbbimh", "datausqpfzxkczbd")))
- .withParameters(mapOf("zl",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataoortclnhbjcy"), "lkv",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datascibv")))
- .withAnnotations(Arrays.asList("dataafnwqh"))
- .withFolder(new DatasetFolder().withName("cnviulby"))
- .withTableName("databgwzhbhflj")
- .withTable("dataod")
- .withSchemaTypePropertiesSchema("dataovnlhrwya");
+ PostgreSqlTableDataset model = new PostgreSqlTableDataset().withDescription("vqxdemklphx")
+ .withStructure("datawlojkbgnfbrzj")
+ .withSchema("datasunhaevlah")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("czywywuahwc")
+ .withParameters(mapOf("jfdaj", "datawcnnaax", "omggew", "datafgi", "yznvussu", "dataqbxex",
+ "xayzqbyeyw", "datakslws")))
+ .withParameters(mapOf("dzt",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datartlikff"),
+ "dteqjmyqxuhg",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datafbgynzfwv"),
+ "wrrlccklyf",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datanyprijyoxxjxbs"),
+ "apvibzi",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataspauemqomxoalknu")))
+ .withAnnotations(Arrays.asList("dataichca"))
+ .withFolder(new DatasetFolder().withName("hjxnrkbnvfccklz"))
+ .withTableName("datansastl")
+ .withTable("datamgomicttrvlv")
+ .withSchemaTypePropertiesSchema("datamxokxxamqecjrzvl");
model = BinaryData.fromObject(model).toObject(PostgreSqlTableDataset.class);
- Assertions.assertEquals("uafapwxsvdeatjio", model.description());
- Assertions.assertEquals("upbmtbsetkods", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("zl").type());
- Assertions.assertEquals("cnviulby", model.folder().name());
+ Assertions.assertEquals("vqxdemklphx", model.description());
+ Assertions.assertEquals("czywywuahwc", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("dzt").type());
+ Assertions.assertEquals("hjxnrkbnvfccklz", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTypePropertiesTests.java
index 44278acb2577..5019d7b83bfc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlTableDatasetTypePropertiesTests.java
@@ -10,17 +10,17 @@
public final class PostgreSqlTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- PostgreSqlTableDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"dataastlpsmgo\",\"table\":\"datac\",\"schema\":\"datarvlvvjmx\"}")
- .toObject(PostgreSqlTableDatasetTypeProperties.class);
+ PostgreSqlTableDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"databvjsbgmlamoax\",\"table\":\"dataytn\",\"schema\":\"datavbpbl\"}")
+ .toObject(PostgreSqlTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
PostgreSqlTableDatasetTypeProperties model
- = new PostgreSqlTableDatasetTypeProperties().withTableName("dataastlpsmgo")
- .withTable("datac")
- .withSchema("datarvlvvjmx");
+ = new PostgreSqlTableDatasetTypeProperties().withTableName("databvjsbgmlamoax")
+ .withTable("dataytn")
+ .withSchema("datavbpbl");
model = BinaryData.fromObject(model).toObject(PostgreSqlTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2SourceTests.java
index 12e284459df7..45a61377472d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2SourceTests.java
@@ -11,19 +11,19 @@ public final class PostgreSqlV2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PostgreSqlV2Source model = BinaryData.fromString(
- "{\"type\":\"PostgreSqlV2Source\",\"query\":\"datapaf\",\"queryTimeout\":\"datax\",\"additionalColumns\":\"dataskelwzmjiigq\",\"sourceRetryCount\":\"datalcckgfoxvrb\",\"sourceRetryWait\":\"datajmenqcjjfxqt\",\"maxConcurrentConnections\":\"datafsvqyzgaweix\",\"disableMetricsCollection\":\"datablazwhdacz\",\"\":{\"zdxu\":\"dataduwlsovitpcsma\",\"ypvu\":\"datahmiu\"}}")
+ "{\"type\":\"PostgreSqlV2Source\",\"query\":\"dataopqtegkrjolbaegh\",\"queryTimeout\":\"datasscismrnneklfi\",\"additionalColumns\":\"dataysfclxtf\",\"sourceRetryCount\":\"datadwqzbiukzmfyfvy\",\"sourceRetryWait\":\"dataofaiwlnfvexiuuqa\",\"maxConcurrentConnections\":\"datalseyxpgkmlnj\",\"disableMetricsCollection\":\"dataaywgc\",\"\":{\"wv\":\"datafafpyglnfwjs\"}}")
.toObject(PostgreSqlV2Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PostgreSqlV2Source model = new PostgreSqlV2Source().withSourceRetryCount("datalcckgfoxvrb")
- .withSourceRetryWait("datajmenqcjjfxqt")
- .withMaxConcurrentConnections("datafsvqyzgaweix")
- .withDisableMetricsCollection("datablazwhdacz")
- .withQueryTimeout("datax")
- .withAdditionalColumns("dataskelwzmjiigq")
- .withQuery("datapaf");
+ PostgreSqlV2Source model = new PostgreSqlV2Source().withSourceRetryCount("datadwqzbiukzmfyfvy")
+ .withSourceRetryWait("dataofaiwlnfvexiuuqa")
+ .withMaxConcurrentConnections("datalseyxpgkmlnj")
+ .withDisableMetricsCollection("dataaywgc")
+ .withQueryTimeout("datasscismrnneklfi")
+ .withAdditionalColumns("dataysfclxtf")
+ .withQuery("dataopqtegkrjolbaegh");
model = BinaryData.fromObject(model).toObject(PostgreSqlV2Source.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTests.java
index 6cf576227f56..8001875c8967 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTests.java
@@ -19,34 +19,41 @@ public final class PostgreSqlV2TableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PostgreSqlV2TableDataset model = BinaryData.fromString(
- "{\"type\":\"PostgreSqlV2Table\",\"typeProperties\":{\"table\":\"dataxamqecjrzvlcivqx\",\"schema\":\"datamklphxwww\"},\"description\":\"jkbgnfbr\",\"structure\":\"datavfsunhaevla\",\"schema\":\"dataczywywuahwc\",\"linkedServiceName\":{\"referenceName\":\"rewcnnaaxqjfda\",\"parameters\":{\"mggewdqbxexfy\":\"datagim\"}},\"parameters\":{\"yzqbye\":{\"type\":\"Bool\",\"defaultValue\":\"datasuqkslwsfx\"},\"kffydztkqrfbgy\":{\"type\":\"Object\",\"defaultValue\":\"datamohnrtl\"}},\"annotations\":[\"datawvzdte\",\"datajmyqxuhgka\",\"datanyprijyoxxjxbs\"],\"folder\":{\"name\":\"rlcck\"},\"\":{\"mqomxoalknuy\":\"datapjmspau\",\"zi\":\"datapvi\"}}")
+ "{\"type\":\"PostgreSqlV2Table\",\"typeProperties\":{\"table\":\"datasexheeocnqoubvep\",\"schema\":\"dataryszfhdxyfh\"},\"description\":\"hzbzhhavz\",\"structure\":\"dataxnvkdslcofuvtfue\",\"schema\":\"datauisaklhjfddxqfu\",\"linkedServiceName\":{\"referenceName\":\"subzsspmj\",\"parameters\":{\"wbztrt\":\"datalfauyvxpqwlkqd\",\"ffjdhgslormhbt\":\"dataldwvog\",\"sdylmnq\":\"datafcvxkylhc\"}},\"parameters\":{\"bgbh\":{\"type\":\"Object\",\"defaultValue\":\"databptmsgkwedwlxtzh\"},\"pkwmamrlfizjud\":{\"type\":\"SecureString\",\"defaultValue\":\"datarpjimvrrqfi\"},\"pngyhylqyafe\":{\"type\":\"String\",\"defaultValue\":\"dataih\"},\"u\":{\"type\":\"Int\",\"defaultValue\":\"dataodx\"}},\"annotations\":[\"dataxnxrqxrtzeargv\"],\"folder\":{\"name\":\"hbjhmvpjxsd\"},\"\":{\"ynepkt\":\"dataignybffqcw\",\"conyse\":\"datamwg\",\"ouoxfalo\":\"datajijfhpxni\"}}")
.toObject(PostgreSqlV2TableDataset.class);
- Assertions.assertEquals("jkbgnfbr", model.description());
- Assertions.assertEquals("rewcnnaaxqjfda", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("yzqbye").type());
- Assertions.assertEquals("rlcck", model.folder().name());
+ Assertions.assertEquals("hzbzhhavz", model.description());
+ Assertions.assertEquals("subzsspmj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("bgbh").type());
+ Assertions.assertEquals("hbjhmvpjxsd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PostgreSqlV2TableDataset model = new PostgreSqlV2TableDataset().withDescription("jkbgnfbr")
- .withStructure("datavfsunhaevla")
- .withSchema("dataczywywuahwc")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rewcnnaaxqjfda")
- .withParameters(mapOf("mggewdqbxexfy", "datagim")))
- .withParameters(mapOf("yzqbye",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datasuqkslwsfx"),
- "kffydztkqrfbgy",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datamohnrtl")))
- .withAnnotations(Arrays.asList("datawvzdte", "datajmyqxuhgka", "datanyprijyoxxjxbs"))
- .withFolder(new DatasetFolder().withName("rlcck"))
- .withTable("dataxamqecjrzvlcivqx")
- .withSchemaTypePropertiesSchema("datamklphxwww");
+ PostgreSqlV2TableDataset model
+ = new PostgreSqlV2TableDataset().withDescription("hzbzhhavz")
+ .withStructure("dataxnvkdslcofuvtfue")
+ .withSchema("datauisaklhjfddxqfu")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("subzsspmj")
+ .withParameters(mapOf("wbztrt", "datalfauyvxpqwlkqd", "ffjdhgslormhbt", "dataldwvog", "sdylmnq",
+ "datafcvxkylhc")))
+ .withParameters(mapOf("bgbh",
+ new ParameterSpecification().withType(ParameterType.OBJECT)
+ .withDefaultValue("databptmsgkwedwlxtzh"),
+ "pkwmamrlfizjud",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datarpjimvrrqfi"),
+ "pngyhylqyafe",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataih"), "u",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataodx")))
+ .withAnnotations(Arrays.asList("dataxnxrqxrtzeargv"))
+ .withFolder(new DatasetFolder().withName("hbjhmvpjxsd"))
+ .withTable("datasexheeocnqoubvep")
+ .withSchemaTypePropertiesSchema("dataryszfhdxyfh");
model = BinaryData.fromObject(model).toObject(PostgreSqlV2TableDataset.class);
- Assertions.assertEquals("jkbgnfbr", model.description());
- Assertions.assertEquals("rewcnnaaxqjfda", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("yzqbye").type());
- Assertions.assertEquals("rlcck", model.folder().name());
+ Assertions.assertEquals("hzbzhhavz", model.description());
+ Assertions.assertEquals("subzsspmj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("bgbh").type());
+ Assertions.assertEquals("hbjhmvpjxsd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTypePropertiesTests.java
index 59a8a0faa268..ab3523081dbd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PostgreSqlV2TableDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class PostgreSqlV2TableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PostgreSqlV2TableDatasetTypeProperties model
- = BinaryData.fromString("{\"table\":\"datavic\",\"schema\":\"dataaptk\"}")
+ = BinaryData.fromString("{\"table\":\"dataskk\",\"schema\":\"dataorsyni\"}")
.toObject(PostgreSqlV2TableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
PostgreSqlV2TableDatasetTypeProperties model
- = new PostgreSqlV2TableDatasetTypeProperties().withTable("datavic").withSchema("dataaptk");
+ = new PostgreSqlV2TableDatasetTypeProperties().withTable("dataskk").withSchema("dataorsyni");
model = BinaryData.fromObject(model).toObject(PostgreSqlV2TableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PowerQuerySinkMappingTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PowerQuerySinkMappingTests.java
index c6e982eb3fb2..5335203a3d1b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PowerQuerySinkMappingTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PowerQuerySinkMappingTests.java
@@ -20,55 +20,76 @@ public final class PowerQuerySinkMappingTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PowerQuerySinkMapping model = BinaryData.fromString(
- "{\"queryName\":\"oo\",\"dataflowSinks\":[{\"script\":\"hhe\",\"schemaLinkedService\":{\"referenceName\":\"j\",\"parameters\":{\"tkkf\":\"datahdonyleisawvdwmu\",\"opot\":\"datatonyrfmozu\"}},\"rejectedDataLinkedService\":{\"referenceName\":\"kyzyi\",\"parameters\":{\"en\":\"datagdkbfqkeaipb\"}},\"name\":\"cvdrpwckivtknuc\",\"description\":\"bax\",\"dataset\":{\"referenceName\":\"erpoasyzze\",\"parameters\":{\"dbix\":\"dataqnn\",\"giydgee\":\"dataudmaniwkwtmqy\",\"llepppdfrgobr\":\"datapivsowcwehjqy\"}},\"linkedService\":{\"referenceName\":\"xcayyvriuvmme\",\"parameters\":{\"czxkxvrig\":\"dataimmwiri\",\"afpiejbpbdu\":\"datautxzascalwfefyg\",\"o\":\"dataaypsvedxphf\",\"mmitvviqs\":\"dataqqwxjnkbes\"}},\"flowlet\":{\"type\":\"DataFlowReference\",\"referenceName\":\"ujhmdpey\",\"datasetParameters\":\"dataqwjqevwtkrjqnciw\",\"parameters\":{\"kgllmpkuxbluc\":\"datawngrrpdtinhc\",\"mpgusroqkjw\":\"datayhtkyqfynvt\"},\"\":{\"gko\":\"datajrkfcjtjqhfkws\"}}}]}")
+ "{\"queryName\":\"igohafudt\",\"dataflowSinks\":[{\"script\":\"pueqgrcn\",\"schemaLinkedService\":{\"referenceName\":\"cqg\",\"parameters\":{\"gjlxdddvfnqaz\":\"datanvfzlmugxpuget\",\"zkdqimu\":\"dataavspjdxay\"}},\"rejectedDataLinkedService\":{\"referenceName\":\"ijcullk\",\"parameters\":{\"vrxy\":\"datasyyredzhnyli\",\"vjsqazecdomjrr\":\"datap\",\"aqxstykus\":\"datalwrvi\"}},\"name\":\"qmgjexiqejvpdrcn\",\"description\":\"x\",\"dataset\":{\"referenceName\":\"rqa\",\"parameters\":{\"zyycev\":\"datar\",\"y\":\"dataazwewhobxlk\",\"nuxvyalkcuozwow\":\"dataspidcnxjfgx\",\"qlb\":\"datamulqgaeqnlx\"}},\"linkedService\":{\"referenceName\":\"zcwfscxkr\",\"parameters\":{\"ko\":\"dataepdvxmkzgrrg\"}},\"flowlet\":{\"type\":\"DataFlowReference\",\"referenceName\":\"ebwdvuvq\",\"datasetParameters\":\"dataplzdoamqkdwa\",\"parameters\":{\"x\":\"dataahu\",\"ura\":\"datapu\",\"ivkmdfwfzkocdj\":\"datafiwjounvfqyk\",\"rbphtllkpkcqzbvy\":\"dataj\"},\"\":{\"mvxrjidxiosype\":\"dataxcba\",\"whbmo\":\"datafrbujltgxhgyllas\",\"yinyqsdsuewfgri\":\"datamhknsknnnpyo\"}}},{\"script\":\"mkmcrtmvtfeyo\",\"schemaLinkedService\":{\"referenceName\":\"eiweb\",\"parameters\":{\"zaxqhlerkyimcfm\":\"datazmggvsxvgwrqywaa\",\"cyxcluvj\":\"datahwtlli\",\"jpld\":\"datap\"}},\"rejectedDataLinkedService\":{\"referenceName\":\"shcjgoobl\",\"parameters\":{\"qwmzzcg\":\"datargcntgq\"}},\"name\":\"gvfs\",\"description\":\"buu\",\"dataset\":{\"referenceName\":\"uqwvybxmu\",\"parameters\":{\"chhrnfa\":\"datakbhymdaeshjj\",\"hmvco\":\"dataqefiwwhbkxzqryov\",\"fmyiwy\":\"dataiagwu\",\"msyfjno\":\"datatau\"}},\"linkedService\":{\"referenceName\":\"ibcez\",\"parameters\":{\"qlbz\":\"datayarlwllgje\",\"guny\":\"datasff\"}},\"flowlet\":{\"type\":\"DataFlowReference\",\"referenceName\":\"yhtspkmkvk\",\"datasetParameters\":\"datakmch\",\"parameters\":{\"cwjqtfsx\":\"datagjvyosmxovyfdbah\"},\"\":{\"eypaoawnkwhiyu\":\"databezdvnezouayvejw\",\"wsjavmr\":\"datajhmjlkk\",\"jnlerm\":\"datarhsv\"}}}]}")
.toObject(PowerQuerySinkMapping.class);
- Assertions.assertEquals("oo", model.queryName());
- Assertions.assertEquals("cvdrpwckivtknuc", model.dataflowSinks().get(0).name());
- Assertions.assertEquals("bax", model.dataflowSinks().get(0).description());
- Assertions.assertEquals("erpoasyzze", model.dataflowSinks().get(0).dataset().referenceName());
- Assertions.assertEquals("xcayyvriuvmme", model.dataflowSinks().get(0).linkedService().referenceName());
+ Assertions.assertEquals("igohafudt", model.queryName());
+ Assertions.assertEquals("qmgjexiqejvpdrcn", model.dataflowSinks().get(0).name());
+ Assertions.assertEquals("x", model.dataflowSinks().get(0).description());
+ Assertions.assertEquals("rqa", model.dataflowSinks().get(0).dataset().referenceName());
+ Assertions.assertEquals("zcwfscxkr", model.dataflowSinks().get(0).linkedService().referenceName());
Assertions.assertEquals(DataFlowReferenceType.DATA_FLOW_REFERENCE,
model.dataflowSinks().get(0).flowlet().type());
- Assertions.assertEquals("ujhmdpey", model.dataflowSinks().get(0).flowlet().referenceName());
- Assertions.assertEquals("j", model.dataflowSinks().get(0).schemaLinkedService().referenceName());
- Assertions.assertEquals("kyzyi", model.dataflowSinks().get(0).rejectedDataLinkedService().referenceName());
- Assertions.assertEquals("hhe", model.dataflowSinks().get(0).script());
+ Assertions.assertEquals("ebwdvuvq", model.dataflowSinks().get(0).flowlet().referenceName());
+ Assertions.assertEquals("cqg", model.dataflowSinks().get(0).schemaLinkedService().referenceName());
+ Assertions.assertEquals("ijcullk", model.dataflowSinks().get(0).rejectedDataLinkedService().referenceName());
+ Assertions.assertEquals("pueqgrcn", model.dataflowSinks().get(0).script());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
PowerQuerySinkMapping model
- = new PowerQuerySinkMapping().withQueryName("oo")
- .withDataflowSinks(Arrays.asList(new PowerQuerySink().withName("cvdrpwckivtknuc")
- .withDescription("bax")
- .withDataset(new DatasetReference().withReferenceName("erpoasyzze")
- .withParameters(mapOf("dbix", "dataqnn", "giydgee", "dataudmaniwkwtmqy", "llepppdfrgobr",
- "datapivsowcwehjqy")))
- .withLinkedService(new LinkedServiceReference().withReferenceName("xcayyvriuvmme")
- .withParameters(mapOf("czxkxvrig", "dataimmwiri", "afpiejbpbdu", "datautxzascalwfefyg", "o",
- "dataaypsvedxphf", "mmitvviqs", "dataqqwxjnkbes")))
- .withFlowlet(new DataFlowReference().withType(DataFlowReferenceType.DATA_FLOW_REFERENCE)
- .withReferenceName("ujhmdpey")
- .withDatasetParameters("dataqwjqevwtkrjqnciw")
- .withParameters(mapOf("kgllmpkuxbluc", "datawngrrpdtinhc", "mpgusroqkjw", "datayhtkyqfynvt"))
- .withAdditionalProperties(mapOf()))
- .withSchemaLinkedService(new LinkedServiceReference().withReferenceName("j")
- .withParameters(mapOf("tkkf", "datahdonyleisawvdwmu", "opot", "datatonyrfmozu")))
- .withRejectedDataLinkedService(new LinkedServiceReference().withReferenceName("kyzyi")
- .withParameters(mapOf("en", "datagdkbfqkeaipb")))
- .withScript("hhe")));
+ = new PowerQuerySinkMapping().withQueryName("igohafudt")
+ .withDataflowSinks(Arrays.asList(
+ new PowerQuerySink().withName("qmgjexiqejvpdrcn")
+ .withDescription("x")
+ .withDataset(new DatasetReference().withReferenceName("rqa")
+ .withParameters(mapOf("zyycev", "datar", "y", "dataazwewhobxlk", "nuxvyalkcuozwow",
+ "dataspidcnxjfgx", "qlb", "datamulqgaeqnlx")))
+ .withLinkedService(new LinkedServiceReference().withReferenceName("zcwfscxkr")
+ .withParameters(mapOf("ko", "dataepdvxmkzgrrg")))
+ .withFlowlet(new DataFlowReference().withType(DataFlowReferenceType.DATA_FLOW_REFERENCE)
+ .withReferenceName("ebwdvuvq")
+ .withDatasetParameters("dataplzdoamqkdwa")
+ .withParameters(mapOf("x", "dataahu", "ura", "datapu", "ivkmdfwfzkocdj", "datafiwjounvfqyk",
+ "rbphtllkpkcqzbvy", "dataj"))
+ .withAdditionalProperties(mapOf()))
+ .withSchemaLinkedService(new LinkedServiceReference().withReferenceName("cqg")
+ .withParameters(mapOf("gjlxdddvfnqaz", "datanvfzlmugxpuget", "zkdqimu", "dataavspjdxay")))
+ .withRejectedDataLinkedService(
+ new LinkedServiceReference().withReferenceName("ijcullk")
+ .withParameters(mapOf("vrxy", "datasyyredzhnyli", "vjsqazecdomjrr", "datap",
+ "aqxstykus", "datalwrvi")))
+ .withScript("pueqgrcn"),
+ new PowerQuerySink().withName("gvfs")
+ .withDescription("buu")
+ .withDataset(new DatasetReference().withReferenceName("uqwvybxmu")
+ .withParameters(mapOf("chhrnfa", "datakbhymdaeshjj", "hmvco", "dataqefiwwhbkxzqryov",
+ "fmyiwy", "dataiagwu", "msyfjno", "datatau")))
+ .withLinkedService(new LinkedServiceReference().withReferenceName("ibcez")
+ .withParameters(mapOf("qlbz", "datayarlwllgje", "guny", "datasff")))
+ .withFlowlet(new DataFlowReference().withType(DataFlowReferenceType.DATA_FLOW_REFERENCE)
+ .withReferenceName("yhtspkmkvk")
+ .withDatasetParameters("datakmch")
+ .withParameters(mapOf("cwjqtfsx", "datagjvyosmxovyfdbah"))
+ .withAdditionalProperties(mapOf()))
+ .withSchemaLinkedService(new LinkedServiceReference().withReferenceName("eiweb")
+ .withParameters(mapOf("zaxqhlerkyimcfm", "datazmggvsxvgwrqywaa", "cyxcluvj", "datahwtlli",
+ "jpld", "datap")))
+ .withRejectedDataLinkedService(new LinkedServiceReference().withReferenceName("shcjgoobl")
+ .withParameters(mapOf("qwmzzcg", "datargcntgq")))
+ .withScript("mkmcrtmvtfeyo")));
model = BinaryData.fromObject(model).toObject(PowerQuerySinkMapping.class);
- Assertions.assertEquals("oo", model.queryName());
- Assertions.assertEquals("cvdrpwckivtknuc", model.dataflowSinks().get(0).name());
- Assertions.assertEquals("bax", model.dataflowSinks().get(0).description());
- Assertions.assertEquals("erpoasyzze", model.dataflowSinks().get(0).dataset().referenceName());
- Assertions.assertEquals("xcayyvriuvmme", model.dataflowSinks().get(0).linkedService().referenceName());
+ Assertions.assertEquals("igohafudt", model.queryName());
+ Assertions.assertEquals("qmgjexiqejvpdrcn", model.dataflowSinks().get(0).name());
+ Assertions.assertEquals("x", model.dataflowSinks().get(0).description());
+ Assertions.assertEquals("rqa", model.dataflowSinks().get(0).dataset().referenceName());
+ Assertions.assertEquals("zcwfscxkr", model.dataflowSinks().get(0).linkedService().referenceName());
Assertions.assertEquals(DataFlowReferenceType.DATA_FLOW_REFERENCE,
model.dataflowSinks().get(0).flowlet().type());
- Assertions.assertEquals("ujhmdpey", model.dataflowSinks().get(0).flowlet().referenceName());
- Assertions.assertEquals("j", model.dataflowSinks().get(0).schemaLinkedService().referenceName());
- Assertions.assertEquals("kyzyi", model.dataflowSinks().get(0).rejectedDataLinkedService().referenceName());
- Assertions.assertEquals("hhe", model.dataflowSinks().get(0).script());
+ Assertions.assertEquals("ebwdvuvq", model.dataflowSinks().get(0).flowlet().referenceName());
+ Assertions.assertEquals("cqg", model.dataflowSinks().get(0).schemaLinkedService().referenceName());
+ Assertions.assertEquals("ijcullk", model.dataflowSinks().get(0).rejectedDataLinkedService().referenceName());
+ Assertions.assertEquals("pueqgrcn", model.dataflowSinks().get(0).script());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoDatasetTypePropertiesTests.java
index af65b0cfc2db..f3822192f5df 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoDatasetTypePropertiesTests.java
@@ -11,15 +11,15 @@ public final class PrestoDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PrestoDatasetTypeProperties model = BinaryData
- .fromString("{\"tableName\":\"datawb\",\"table\":\"dataiwtwfgoc\",\"schema\":\"datalvemnnzugabk\"}")
+ .fromString("{\"tableName\":\"datafmoubukqm\",\"table\":\"datarzrnobvvequz\",\"schema\":\"dataapg\"}")
.toObject(PrestoDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PrestoDatasetTypeProperties model = new PrestoDatasetTypeProperties().withTableName("datawb")
- .withTable("dataiwtwfgoc")
- .withSchema("datalvemnnzugabk");
+ PrestoDatasetTypeProperties model = new PrestoDatasetTypeProperties().withTableName("datafmoubukqm")
+ .withTable("datarzrnobvvequz")
+ .withSchema("dataapg");
model = BinaryData.fromObject(model).toObject(PrestoDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoObjectDatasetTests.java
index 9bf710ba5589..d1e8d381e19f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoObjectDatasetTests.java
@@ -19,34 +19,34 @@ public final class PrestoObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PrestoObjectDataset model = BinaryData.fromString(
- "{\"type\":\"PrestoObject\",\"typeProperties\":{\"tableName\":\"dataz\",\"table\":\"datayujxysv\",\"schema\":\"dataf\"},\"description\":\"clvildlf\",\"structure\":\"dataleirmtxfqpfildcg\",\"schema\":\"dataou\",\"linkedServiceName\":{\"referenceName\":\"fbpgcryvidbzdy\",\"parameters\":{\"jftecgprzsqmp\":\"datajatgngwn\",\"akzbyqha\":\"dataq\"}},\"parameters\":{\"lusyruxrz\":{\"type\":\"Array\",\"defaultValue\":\"datayxuuc\"},\"tpiforomppz\":{\"type\":\"Float\",\"defaultValue\":\"datahrvmgsbpgmncr\"}},\"annotations\":[\"dataqmeu\"],\"folder\":{\"name\":\"fcmpuaiugoceqtl\"},\"\":{\"ncfunlakgixhqjqh\":\"datajymwiccu\"}}")
+ "{\"type\":\"PrestoObject\",\"typeProperties\":{\"tableName\":\"dataceqtl\",\"table\":\"datap\",\"schema\":\"datam\"},\"description\":\"ccurn\",\"structure\":\"dataunlakgixhqj\",\"schema\":\"datagqwbbxiwtwfgo\",\"linkedServiceName\":{\"referenceName\":\"lalvemnnzug\",\"parameters\":{\"mtsnvo\":\"datayydsyweoh\",\"tsw\":\"datavb\",\"vdticcaf\":\"datadopnsep\",\"ppwxnikfz\":\"datagzwkopxdkbtwoqh\"}},\"parameters\":{\"jzrfx\":{\"type\":\"Array\",\"defaultValue\":\"dataduvqzjnnuww\"}},\"annotations\":[\"databcqjkbkjcurxrjw\",\"datazrieitqmlzuw\"],\"folder\":{\"name\":\"zqajxkmpe\"},\"\":{\"eszunb\":\"datalgeehbdjgplnlxr\"}}")
.toObject(PrestoObjectDataset.class);
- Assertions.assertEquals("clvildlf", model.description());
- Assertions.assertEquals("fbpgcryvidbzdy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("lusyruxrz").type());
- Assertions.assertEquals("fcmpuaiugoceqtl", model.folder().name());
+ Assertions.assertEquals("ccurn", model.description());
+ Assertions.assertEquals("lalvemnnzug", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("jzrfx").type());
+ Assertions.assertEquals("zqajxkmpe", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PrestoObjectDataset model = new PrestoObjectDataset().withDescription("clvildlf")
- .withStructure("dataleirmtxfqpfildcg")
- .withSchema("dataou")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("fbpgcryvidbzdy")
- .withParameters(mapOf("jftecgprzsqmp", "datajatgngwn", "akzbyqha", "dataq")))
- .withParameters(mapOf("lusyruxrz",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datayxuuc"), "tpiforomppz",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datahrvmgsbpgmncr")))
- .withAnnotations(Arrays.asList("dataqmeu"))
- .withFolder(new DatasetFolder().withName("fcmpuaiugoceqtl"))
- .withTableName("dataz")
- .withTable("datayujxysv")
- .withSchemaTypePropertiesSchema("dataf");
+ PrestoObjectDataset model = new PrestoObjectDataset().withDescription("ccurn")
+ .withStructure("dataunlakgixhqj")
+ .withSchema("datagqwbbxiwtwfgo")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lalvemnnzug")
+ .withParameters(mapOf("mtsnvo", "datayydsyweoh", "tsw", "datavb", "vdticcaf", "datadopnsep",
+ "ppwxnikfz", "datagzwkopxdkbtwoqh")))
+ .withParameters(mapOf("jzrfx",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataduvqzjnnuww")))
+ .withAnnotations(Arrays.asList("databcqjkbkjcurxrjw", "datazrieitqmlzuw"))
+ .withFolder(new DatasetFolder().withName("zqajxkmpe"))
+ .withTableName("dataceqtl")
+ .withTable("datap")
+ .withSchemaTypePropertiesSchema("datam");
model = BinaryData.fromObject(model).toObject(PrestoObjectDataset.class);
- Assertions.assertEquals("clvildlf", model.description());
- Assertions.assertEquals("fbpgcryvidbzdy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("lusyruxrz").type());
- Assertions.assertEquals("fcmpuaiugoceqtl", model.folder().name());
+ Assertions.assertEquals("ccurn", model.description());
+ Assertions.assertEquals("lalvemnnzug", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("jzrfx").type());
+ Assertions.assertEquals("zqajxkmpe", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoSourceTests.java
index 733a628e01ae..9c1361522c28 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrestoSourceTests.java
@@ -11,19 +11,19 @@ public final class PrestoSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
PrestoSource model = BinaryData.fromString(
- "{\"type\":\"PrestoSource\",\"query\":\"datawevlohuahl\",\"queryTimeout\":\"datacboxgpmmz\",\"additionalColumns\":\"dataoyllxc\",\"sourceRetryCount\":\"datahzylspz\",\"sourceRetryWait\":\"datarhynlbtr\",\"maxConcurrentConnections\":\"dataecvag\",\"disableMetricsCollection\":\"datarhadg\",\"\":{\"hiafbhzdjv\":\"datarasxeomjqqhbkxi\",\"ggbpdpzgvq\":\"datayrzi\",\"lvxilaytj\":\"dataznxzaliicrutyhm\",\"ghqdlj\":\"datawfqzwn\"}}")
+ "{\"type\":\"PrestoSource\",\"query\":\"datayddijfkktigisee\",\"queryTimeout\":\"datazrerxyds\",\"additionalColumns\":\"datapn\",\"sourceRetryCount\":\"dataarkjt\",\"sourceRetryWait\":\"dataaczkjkfakgrwt\",\"maxConcurrentConnections\":\"datasfanmjmpce\",\"disableMetricsCollection\":\"datamfdylvpyhhgqysz\",\"\":{\"jekolnylpyk\":\"datajzhvej\",\"aouyaanfxai\":\"datapa\"}}")
.toObject(PrestoSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- PrestoSource model = new PrestoSource().withSourceRetryCount("datahzylspz")
- .withSourceRetryWait("datarhynlbtr")
- .withMaxConcurrentConnections("dataecvag")
- .withDisableMetricsCollection("datarhadg")
- .withQueryTimeout("datacboxgpmmz")
- .withAdditionalColumns("dataoyllxc")
- .withQuery("datawevlohuahl");
+ PrestoSource model = new PrestoSource().withSourceRetryCount("dataarkjt")
+ .withSourceRetryWait("dataaczkjkfakgrwt")
+ .withMaxConcurrentConnections("datasfanmjmpce")
+ .withDisableMetricsCollection("datamfdylvpyhhgqysz")
+ .withQueryTimeout("datazrerxyds")
+ .withAdditionalColumns("datapn")
+ .withQuery("datayddijfkktigisee");
model = BinaryData.fromObject(model).toObject(PrestoSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndPointConnectionsListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndPointConnectionsListByFactoryMockTests.java
index f572e00dca5d..bebb95a12d33 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndPointConnectionsListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndPointConnectionsListByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class PrivateEndPointConnectionsListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"provisioningState\":\"pmbtmcp\",\"privateEndpoint\":{\"id\":\"p\"},\"privateLinkServiceConnectionState\":{\"status\":\"xamsgfvuffd\",\"description\":\"k\",\"actionsRequired\":\"kmd\"}},\"name\":\"rgmjpckefw\",\"type\":\"u\",\"etag\":\"a\",\"id\":\"ysyprskjii\"}]}";
+ = "{\"value\":[{\"properties\":{\"provisioningState\":\"tonovveouwixte\",\"privateEndpoint\":{\"id\":\"qprhzsaquha\"},\"privateLinkServiceConnectionState\":{\"status\":\"pbbwicteqwjlynlr\",\"description\":\"ydzmbvsladxswot\",\"actionsRequired\":\"xadkiqapt\"}},\"name\":\"bybsgvzevp\",\"type\":\"kfvwlzvxjxvs\",\"etag\":\"bfkelqzcpts\",\"id\":\"ruydiwsfva\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,14 +32,14 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response = manager.privateEndPointConnections()
- .listByFactory("uyoydzafknnl", "sfbpjyvuhy", com.azure.core.util.Context.NONE);
+ .listByFactory("vqus", "rkoqdqjhhtxnocix", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("ysyprskjii", response.iterator().next().id());
- Assertions.assertEquals("xamsgfvuffd",
+ Assertions.assertEquals("ruydiwsfva", response.iterator().next().id());
+ Assertions.assertEquals("pbbwicteqwjlynlr",
response.iterator().next().properties().privateLinkServiceConnectionState().status());
- Assertions.assertEquals("k",
+ Assertions.assertEquals("ydzmbvsladxswot",
response.iterator().next().properties().privateLinkServiceConnectionState().description());
- Assertions.assertEquals("kmd",
+ Assertions.assertEquals("xadkiqapt",
response.iterator().next().properties().privateLinkServiceConnectionState().actionsRequired());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsCreateOrUpdateWithResponseMockTests.java
index 14c8e4c18a6a..b1a7b59bc004 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsCreateOrUpdateWithResponseMockTests.java
@@ -24,7 +24,7 @@ public final class PrivateEndpointConnectionOperationsCreateOrUpdateWithResponse
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"provisioningState\":\"c\",\"privateEndpoint\":{\"id\":\"juuii\"},\"privateLinkServiceConnectionState\":{\"status\":\"t\",\"description\":\"rbo\",\"actionsRequired\":\"xyhpukcmxbis\"}},\"name\":\"itjovjrirg\",\"type\":\"soacbxbioxtqxrbr\",\"etag\":\"znuyczlyl\",\"id\":\"rziaxigeosmuh\"}";
+ = "{\"properties\":{\"provisioningState\":\"bgitkowflc\",\"privateEndpoint\":{\"id\":\"wysv\"},\"privateLinkServiceConnectionState\":{\"status\":\"qqgaysynejdvt\",\"description\":\"gwxilbazrui\",\"actionsRequired\":\"slbrowbfsly\"}},\"name\":\"zwqlhxgsjzrifgu\",\"type\":\"n\",\"etag\":\"wlernchdxpsonkk\",\"id\":\"amojzrngmkeun\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -33,21 +33,22 @@ public void testCreateOrUpdateWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- PrivateEndpointConnectionResource response = manager.privateEndpointConnectionOperations()
- .define("t")
- .withExistingFactory("jnoibclfqdtfj", "tvohywyv")
- .withProperties(new PrivateLinkConnectionApprovalRequest()
- .withPrivateLinkServiceConnectionState(new PrivateLinkConnectionState().withStatus("lqyhabgocqry")
- .withDescription("vofnhckll")
- .withActionsRequired("grkvlqqkpxvemj"))
- .withPrivateEndpoint(new PrivateEndpoint().withId("anefwsodnlwonpb")))
- .withIfMatch("eodhtltooikz")
- .create();
+ PrivateEndpointConnectionResource response
+ = manager.privateEndpointConnectionOperations()
+ .define("inldmflngjtltxfo")
+ .withExistingFactory("nwjowgdw", "peyyzmxuelplbbs")
+ .withProperties(new PrivateLinkConnectionApprovalRequest()
+ .withPrivateLinkServiceConnectionState(new PrivateLinkConnectionState().withStatus("leylv")
+ .withDescription("xlptockgjvflc")
+ .withActionsRequired("sbx"))
+ .withPrivateEndpoint(new PrivateEndpoint().withId("eywmqhnlsmfqgl")))
+ .withIfMatch("gjp")
+ .create();
- Assertions.assertEquals("rziaxigeosmuh", response.id());
- Assertions.assertEquals("t", response.properties().privateLinkServiceConnectionState().status());
- Assertions.assertEquals("rbo", response.properties().privateLinkServiceConnectionState().description());
- Assertions.assertEquals("xyhpukcmxbis",
+ Assertions.assertEquals("amojzrngmkeun", response.id());
+ Assertions.assertEquals("qqgaysynejdvt", response.properties().privateLinkServiceConnectionState().status());
+ Assertions.assertEquals("gwxilbazrui", response.properties().privateLinkServiceConnectionState().description());
+ Assertions.assertEquals("slbrowbfsly",
response.properties().privateLinkServiceConnectionState().actionsRequired());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsDeleteWithResponseMockTests.java
index e1b3a4d8174e..ed098bc149e5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsDeleteWithResponseMockTests.java
@@ -28,7 +28,7 @@ public void testDeleteWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.privateEndpointConnectionOperations()
- .deleteWithResponse("ebx", "dahhiid", "ogakrpmjodbdcy", com.azure.core.util.Context.NONE);
+ .deleteWithResponse("midgoyawgpsx", "ymmsimbesg", "h", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsGetWithResponseMockTests.java
index 22184a606d25..571714348d53 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateEndpointConnectionOperationsGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class PrivateEndpointConnectionOperationsGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"provisioningState\":\"uzhidpxv\",\"privateEndpoint\":{\"id\":\"aftfdxhfusjxnadi\"},\"privateLinkServiceConnectionState\":{\"status\":\"dzfhzihrxgvubs\",\"description\":\"jr\",\"actionsRequired\":\"oujvz\"}},\"name\":\"isqflmalmxv\",\"type\":\"dp\",\"etag\":\"njkenrl\",\"id\":\"mslpg\"}";
+ = "{\"properties\":{\"provisioningState\":\"siinm\",\"privateEndpoint\":{\"id\":\"dtuydynugkjzp\"},\"privateLinkServiceConnectionState\":{\"status\":\"rfhpcyuaj\",\"description\":\"ou\",\"actionsRequired\":\"x\"}},\"name\":\"uzls\",\"type\":\"bsghzund\",\"etag\":\"bmuvgfkdea\",\"id\":\"xdwwraimjkaz\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,13 +31,12 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PrivateEndpointConnectionResource response = manager.privateEndpointConnectionOperations()
- .getWithResponse("vbvkvomnoslbkrh", "nvozjudg", "dsflitmm", "vuzofuebabrsfu",
- com.azure.core.util.Context.NONE)
+ .getWithResponse("pzabbfdhissde", "yecj", "fafmkf", "yyfthsafv", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("mslpg", response.id());
- Assertions.assertEquals("dzfhzihrxgvubs", response.properties().privateLinkServiceConnectionState().status());
- Assertions.assertEquals("jr", response.properties().privateLinkServiceConnectionState().description());
- Assertions.assertEquals("oujvz", response.properties().privateLinkServiceConnectionState().actionsRequired());
+ Assertions.assertEquals("xdwwraimjkaz", response.id());
+ Assertions.assertEquals("rfhpcyuaj", response.properties().privateLinkServiceConnectionState().status());
+ Assertions.assertEquals("ou", response.properties().privateLinkServiceConnectionState().description());
+ Assertions.assertEquals("x", response.properties().privateLinkServiceConnectionState().actionsRequired());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateLinkResourcesGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateLinkResourcesGetWithResponseMockTests.java
index 1a95a578b2ef..c4b485254b7e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateLinkResourcesGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/PrivateLinkResourcesGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class PrivateLinkResourcesGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"groupId\":\"scnbrwhsq\",\"requiredMembers\":[\"m\"],\"requiredZoneNames\":[\"ryexhdigmgs\",\"zhxvaunuus\",\"tzfvzlqspavxfpbi\"]},\"name\":\"sbzu\",\"type\":\"ranngwldymuehv\",\"etag\":\"rtsnclzyun\",\"id\":\"ogagtjcmlyhp\"},{\"properties\":{\"groupId\":\"ix\",\"requiredMembers\":[\"vkwenlc\",\"toibgvaaz\"],\"requiredZoneNames\":[\"aocfnffjxdcc\",\"uzqwvckewlyrw\"]},\"name\":\"psubawzaf\",\"type\":\"zh\",\"etag\":\"bxcelvaww\",\"id\":\"btkyjvzz\"},{\"properties\":{\"groupId\":\"li\",\"requiredMembers\":[\"chsjuacdq\",\"ryo\",\"kqo\"],\"requiredZoneNames\":[\"epml\",\"kzdwietfxpdzzli\",\"k\"]},\"name\":\"wfkanuqfle\",\"type\":\"mr\",\"etag\":\"xniibcilyg\",\"id\":\"i\"},{\"properties\":{\"groupId\":\"jhqfuqomwhhigy\",\"requiredMembers\":[\"ewcvlj\"],\"requiredZoneNames\":[\"nersgrtjmdepa\",\"nywknucsr\",\"fmcrye\"]},\"name\":\"lx\",\"type\":\"hntsqsphieqgoioe\",\"etag\":\"ott\",\"id\":\"fkwzkwuwgzver\"}]}";
+ = "{\"value\":[{\"properties\":{\"groupId\":\"x\",\"requiredMembers\":[\"vodqnenq\",\"clnrctrpun\",\"bhoety\"],\"requiredZoneNames\":[\"cerhhzjhmxyns\"]},\"name\":\"dgvjwoxmlbxqwsec\",\"type\":\"woibqnuhrtiwnbq\",\"etag\":\"saolcebwditccu\",\"id\":\"lcmzghaolfupxh\"},{\"properties\":{\"groupId\":\"tknmp\",\"requiredMembers\":[\"cr\",\"xkvuzpso\",\"jctvu\",\"pjwwv\"],\"requiredZoneNames\":[\"jchizhicxlmym\"]},\"name\":\"uhqetmpqcxrwtyg\",\"type\":\"owrtniymaznmql\",\"etag\":\"tppagvfnryjqboy\",\"id\":\"zwqzvmftxkwicg\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,9 +31,9 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PrivateLinkResourcesWrapper response = manager.privateLinkResources()
- .getWithResponse("hnzsrgiwvzepg", "jtuzqreprn", com.azure.core.util.Context.NONE)
+ .getWithResponse("btms", "nacgbwmqgyak", com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("ogagtjcmlyhp", response.value().get(0).id());
+ Assertions.assertEquals("lcmzghaolfupxh", response.value().get(0).id());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksObjectDatasetTests.java
index 6e49b346d685..a3151aeb2837 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksObjectDatasetTests.java
@@ -19,32 +19,35 @@ public final class QuickBooksObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
QuickBooksObjectDataset model = BinaryData.fromString(
- "{\"type\":\"QuickBooksObject\",\"typeProperties\":{\"tableName\":\"datasyweohlmtsnvon\"},\"description\":\"ftswcd\",\"structure\":\"datanseptvdtic\",\"schema\":\"datafl\",\"linkedServiceName\":{\"referenceName\":\"zwkopxd\",\"parameters\":{\"kfzrxxf\":\"datawoqhgppwxn\",\"jzrfx\":\"dataduvqzjnnuww\"}},\"parameters\":{\"rxrjwyzrieitq\":{\"type\":\"Bool\",\"defaultValue\":\"dataqjkbkjc\"},\"pebfhlgeeh\":{\"type\":\"String\",\"defaultValue\":\"datauwtbdzqajxk\"}},\"annotations\":[\"datagplnl\",\"datarfe\",\"datazunbua\",\"datamoub\"],\"folder\":{\"name\":\"mi\"},\"\":{\"yt\":\"datarnobvvequ\"}}")
+ "{\"type\":\"QuickBooksObject\",\"typeProperties\":{\"tableName\":\"datazbjecdsysxnkuhv\"},\"description\":\"lsevzc\",\"structure\":\"datawnkkgdwqymxsfqea\",\"schema\":\"dataqe\",\"linkedServiceName\":{\"referenceName\":\"uvmsaq\",\"parameters\":{\"vzfznfgpb\":\"dataawgqrwuh\"}},\"parameters\":{\"lkqcln\":{\"type\":\"Object\",\"defaultValue\":\"dataympdjieas\"},\"ahvyeikbvqzr\":{\"type\":\"Bool\",\"defaultValue\":\"datargnoskkhbmjphlyy\"},\"ucpckxjnohafw\":{\"type\":\"String\",\"defaultValue\":\"databq\"},\"e\":{\"type\":\"Float\",\"defaultValue\":\"datagjlyxtugpea\"}},\"annotations\":[\"datawxfamtxccfegsavb\"],\"folder\":{\"name\":\"ucv\"},\"\":{\"mazkmqfw\":\"datadhoo\"}}")
.toObject(QuickBooksObjectDataset.class);
- Assertions.assertEquals("ftswcd", model.description());
- Assertions.assertEquals("zwkopxd", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("rxrjwyzrieitq").type());
- Assertions.assertEquals("mi", model.folder().name());
+ Assertions.assertEquals("lsevzc", model.description());
+ Assertions.assertEquals("uvmsaq", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("lkqcln").type());
+ Assertions.assertEquals("ucv", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- QuickBooksObjectDataset model = new QuickBooksObjectDataset().withDescription("ftswcd")
- .withStructure("datanseptvdtic")
- .withSchema("datafl")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zwkopxd")
- .withParameters(mapOf("kfzrxxf", "datawoqhgppwxn", "jzrfx", "dataduvqzjnnuww")))
- .withParameters(mapOf("rxrjwyzrieitq",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataqjkbkjc"), "pebfhlgeeh",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datauwtbdzqajxk")))
- .withAnnotations(Arrays.asList("datagplnl", "datarfe", "datazunbua", "datamoub"))
- .withFolder(new DatasetFolder().withName("mi"))
- .withTableName("datasyweohlmtsnvon");
+ QuickBooksObjectDataset model = new QuickBooksObjectDataset().withDescription("lsevzc")
+ .withStructure("datawnkkgdwqymxsfqea")
+ .withSchema("dataqe")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("uvmsaq")
+ .withParameters(mapOf("vzfznfgpb", "dataawgqrwuh")))
+ .withParameters(mapOf("lkqcln",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataympdjieas"),
+ "ahvyeikbvqzr",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datargnoskkhbmjphlyy"),
+ "ucpckxjnohafw", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("databq"),
+ "e", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datagjlyxtugpea")))
+ .withAnnotations(Arrays.asList("datawxfamtxccfegsavb"))
+ .withFolder(new DatasetFolder().withName("ucv"))
+ .withTableName("datazbjecdsysxnkuhv");
model = BinaryData.fromObject(model).toObject(QuickBooksObjectDataset.class);
- Assertions.assertEquals("ftswcd", model.description());
- Assertions.assertEquals("zwkopxd", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("rxrjwyzrieitq").type());
- Assertions.assertEquals("mi", model.folder().name());
+ Assertions.assertEquals("lsevzc", model.description());
+ Assertions.assertEquals("uvmsaq", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("lkqcln").type());
+ Assertions.assertEquals("ucv", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksSourceTests.java
index cc44b1866365..3e7045348c3d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/QuickBooksSourceTests.java
@@ -11,19 +11,19 @@ public final class QuickBooksSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
QuickBooksSource model = BinaryData.fromString(
- "{\"type\":\"QuickBooksSource\",\"query\":\"dataqngpvvnbu\",\"queryTimeout\":\"datavkutl\",\"additionalColumns\":\"dataxuuqb\",\"sourceRetryCount\":\"datapbeswgkreozpufk\",\"sourceRetryWait\":\"datamzcbzgi\",\"maxConcurrentConnections\":\"dataqpegcgdndpb\",\"disableMetricsCollection\":\"dataeymmcbiktetzvqt\",\"\":{\"pdnbzqweohmlkzhx\":\"datavcsbyimygswdu\",\"haerhxd\":\"datadmauanxzrqt\",\"bqmoguy\":\"datahkbrkhjjbwelicrx\",\"dxljjzdbzk\":\"datamselwszqveak\"}}")
+ "{\"type\":\"QuickBooksSource\",\"query\":\"dataeycakkon\",\"queryTimeout\":\"datadpd\",\"additionalColumns\":\"datahadzyxaanhwuqewc\",\"sourceRetryCount\":\"datasksfbkxfkeeqo\",\"sourceRetryWait\":\"databek\",\"maxConcurrentConnections\":\"dataerwss\",\"disableMetricsCollection\":\"datamrpdjrylfpdudx\",\"\":{\"tqssngeviyffg\":\"dataeuriehxbanfsqfh\",\"hdapynpvgyaf\":\"datahrhjsps\"}}")
.toObject(QuickBooksSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- QuickBooksSource model = new QuickBooksSource().withSourceRetryCount("datapbeswgkreozpufk")
- .withSourceRetryWait("datamzcbzgi")
- .withMaxConcurrentConnections("dataqpegcgdndpb")
- .withDisableMetricsCollection("dataeymmcbiktetzvqt")
- .withQueryTimeout("datavkutl")
- .withAdditionalColumns("dataxuuqb")
- .withQuery("dataqngpvvnbu");
+ QuickBooksSource model = new QuickBooksSource().withSourceRetryCount("datasksfbkxfkeeqo")
+ .withSourceRetryWait("databek")
+ .withMaxConcurrentConnections("dataerwss")
+ .withDisableMetricsCollection("datamrpdjrylfpdudx")
+ .withQueryTimeout("datadpd")
+ .withAdditionalColumns("datahadzyxaanhwuqewc")
+ .withQuery("dataeycakkon");
model = BinaryData.fromObject(model).toObject(QuickBooksSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleOccurrenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleOccurrenceTests.java
index 84c0fdaee419..e0413142157d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleOccurrenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleOccurrenceTests.java
@@ -14,21 +14,21 @@
public final class RecurrenceScheduleOccurrenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- RecurrenceScheduleOccurrence model
- = BinaryData.fromString("{\"day\":\"Saturday\",\"occurrence\":866000877,\"\":{\"jnvmfm\":\"datao\"}}")
- .toObject(RecurrenceScheduleOccurrence.class);
+ RecurrenceScheduleOccurrence model = BinaryData.fromString(
+ "{\"day\":\"Saturday\",\"occurrence\":423104171,\"\":{\"dshkbfweez\":\"datanngutitjwvvva\",\"nn\":\"datarzfyt\",\"dphi\":\"dataxgofiphlwy\",\"ztsgklu\":\"datahkigslczkzl\"}}")
+ .toObject(RecurrenceScheduleOccurrence.class);
Assertions.assertEquals(DayOfWeek.SATURDAY, model.day());
- Assertions.assertEquals(866000877, model.occurrence());
+ Assertions.assertEquals(423104171, model.occurrence());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
RecurrenceScheduleOccurrence model = new RecurrenceScheduleOccurrence().withDay(DayOfWeek.SATURDAY)
- .withOccurrence(866000877)
+ .withOccurrence(423104171)
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(RecurrenceScheduleOccurrence.class);
Assertions.assertEquals(DayOfWeek.SATURDAY, model.day());
- Assertions.assertEquals(866000877, model.occurrence());
+ Assertions.assertEquals(423104171, model.occurrence());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleTests.java
index 55a343067b7a..fd3841693058 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RecurrenceScheduleTests.java
@@ -18,37 +18,44 @@ public final class RecurrenceScheduleTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RecurrenceSchedule model = BinaryData.fromString(
- "{\"minutes\":[1595972014,1433983322],\"hours\":[361140125,2089173549,318625791,687688636],\"weekDays\":[\"Saturday\",\"Saturday\",\"Saturday\"],\"monthDays\":[308225619,1477806779],\"monthlyOccurrences\":[{\"day\":\"Tuesday\",\"occurrence\":456629767,\"\":{\"lvea\":\"datalyoiyovcrmo\",\"ezrajpedowmh\":\"datauz\",\"xnopdeqqf\":\"datazrrikvyu\"}},{\"day\":\"Friday\",\"occurrence\":992003430,\"\":{\"hvpx\":\"datafikiu\",\"mxnjk\":\"datatqbwneilg\",\"llcykihymdguk\":\"dataspnsbbhdjee\",\"oh\":\"datamkqokzvxknygi\"}}],\"\":{\"zchqwnud\":\"dataxjyxhwvnyup\",\"ib\":\"datalazvsmnxblc\",\"eh\":\"datamgfwdxukmeo\",\"rbwvai\":\"datan\"}}")
+ "{\"minutes\":[375537031,1717718914,372186737,1764050808],\"hours\":[262504222,1587118023,325450941,810878790],\"weekDays\":[\"Wednesday\"],\"monthDays\":[1241874594],\"monthlyOccurrences\":[{\"day\":\"Thursday\",\"occurrence\":514886352,\"\":{\"hxphuplfopqgcadn\":\"datayfpfaa\",\"oygcofh\":\"datazfjldnvfpmez\"}},{\"day\":\"Wednesday\",\"occurrence\":404410098,\"\":{\"xbaazn\":\"databgmxm\",\"ybndiqpadhrij\":\"datawuwbnngcdtxxyz\",\"lqsfpctqgrnb\":\"datauqtjcyllpas\",\"vcabchdzx\":\"datajdefsqunernbd\"}},{\"day\":\"Wednesday\",\"occurrence\":1181308151,\"\":{\"mnfavllbskl\":\"dataaadcz\",\"kcea\":\"dataakkihxpofv\",\"vawbt\":\"dataorppzb\",\"egknaec\":\"datavq\"}},{\"day\":\"Tuesday\",\"occurrence\":1250228809,\"\":{\"dswhbsej\":\"dataqocdrjguhsjlroa\",\"yjtollugzsvzi\":\"datauboyrf\"}}],\"\":{\"llmutwmarfbszlp\":\"datasbdaudsvdb\",\"czrd\":\"datax\",\"mkw\":\"databeb\"}}")
.toObject(RecurrenceSchedule.class);
- Assertions.assertEquals(1595972014, model.minutes().get(0));
- Assertions.assertEquals(361140125, model.hours().get(0));
- Assertions.assertEquals(DaysOfWeek.SATURDAY, model.weekDays().get(0));
- Assertions.assertEquals(308225619, model.monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.TUESDAY, model.monthlyOccurrences().get(0).day());
- Assertions.assertEquals(456629767, model.monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals(375537031, model.minutes().get(0));
+ Assertions.assertEquals(262504222, model.hours().get(0));
+ Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.weekDays().get(0));
+ Assertions.assertEquals(1241874594, model.monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.THURSDAY, model.monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(514886352, model.monthlyOccurrences().get(0).occurrence());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RecurrenceSchedule model = new RecurrenceSchedule().withMinutes(Arrays.asList(1595972014, 1433983322))
- .withHours(Arrays.asList(361140125, 2089173549, 318625791, 687688636))
- .withWeekDays(Arrays.asList(DaysOfWeek.SATURDAY, DaysOfWeek.SATURDAY, DaysOfWeek.SATURDAY))
- .withMonthDays(Arrays.asList(308225619, 1477806779))
- .withMonthlyOccurrences(Arrays.asList(
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.TUESDAY)
- .withOccurrence(456629767)
- .withAdditionalProperties(mapOf()),
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.FRIDAY)
- .withOccurrence(992003430)
- .withAdditionalProperties(mapOf())))
- .withAdditionalProperties(mapOf());
+ RecurrenceSchedule model
+ = new RecurrenceSchedule().withMinutes(Arrays.asList(375537031, 1717718914, 372186737, 1764050808))
+ .withHours(Arrays.asList(262504222, 1587118023, 325450941, 810878790))
+ .withWeekDays(Arrays.asList(DaysOfWeek.WEDNESDAY))
+ .withMonthDays(Arrays.asList(1241874594))
+ .withMonthlyOccurrences(Arrays.asList(
+ new RecurrenceScheduleOccurrence().withDay(DayOfWeek.THURSDAY)
+ .withOccurrence(514886352)
+ .withAdditionalProperties(mapOf()),
+ new RecurrenceScheduleOccurrence().withDay(DayOfWeek.WEDNESDAY)
+ .withOccurrence(404410098)
+ .withAdditionalProperties(mapOf()),
+ new RecurrenceScheduleOccurrence().withDay(DayOfWeek.WEDNESDAY)
+ .withOccurrence(1181308151)
+ .withAdditionalProperties(mapOf()),
+ new RecurrenceScheduleOccurrence().withDay(DayOfWeek.TUESDAY)
+ .withOccurrence(1250228809)
+ .withAdditionalProperties(mapOf())))
+ .withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(RecurrenceSchedule.class);
- Assertions.assertEquals(1595972014, model.minutes().get(0));
- Assertions.assertEquals(361140125, model.hours().get(0));
- Assertions.assertEquals(DaysOfWeek.SATURDAY, model.weekDays().get(0));
- Assertions.assertEquals(308225619, model.monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.TUESDAY, model.monthlyOccurrences().get(0).day());
- Assertions.assertEquals(456629767, model.monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals(375537031, model.minutes().get(0));
+ Assertions.assertEquals(262504222, model.hours().get(0));
+ Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.weekDays().get(0));
+ Assertions.assertEquals(1241874594, model.monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.THURSDAY, model.monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(514886352, model.monthlyOccurrences().get(0).occurrence());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedirectIncompatibleRowSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedirectIncompatibleRowSettingsTests.java
index c73db202ad92..2a0ac7f3bf7b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedirectIncompatibleRowSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedirectIncompatibleRowSettingsTests.java
@@ -13,15 +13,15 @@ public final class RedirectIncompatibleRowSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RedirectIncompatibleRowSettings model = BinaryData.fromString(
- "{\"linkedServiceName\":\"datazwaewpilsuhsghd\",\"path\":\"datacpbwfnapga\",\"\":{\"whh\":\"datasixzcdaukh\",\"fnbzamroaduto\":\"datacbomfoojkerdu\",\"cnecl\":\"databkdctsgvalh\"}}")
+ "{\"linkedServiceName\":\"databsspexejhwpnjc\",\"path\":\"datacj\",\"\":{\"jsrdecbowkhma\":\"datavuvmdzdqtirgu\",\"sujx\":\"datafllpdn\",\"aeykueat\":\"dataueqljzkhn\"}}")
.toObject(RedirectIncompatibleRowSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
RedirectIncompatibleRowSettings model
- = new RedirectIncompatibleRowSettings().withLinkedServiceName("datazwaewpilsuhsghd")
- .withPath("datacpbwfnapga")
+ = new RedirectIncompatibleRowSettings().withLinkedServiceName("databsspexejhwpnjc")
+ .withPath("datacj")
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(RedirectIncompatibleRowSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedshiftUnloadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedshiftUnloadSettingsTests.java
index 08018b06c124..82fcad5d1ff3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedshiftUnloadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RedshiftUnloadSettingsTests.java
@@ -15,20 +15,19 @@ public final class RedshiftUnloadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RedshiftUnloadSettings model = BinaryData.fromString(
- "{\"s3LinkedServiceName\":{\"referenceName\":\"snozjn\",\"parameters\":{\"qxelmmxwmpziycns\":\"datacmhonojese\",\"kfofyfw\":\"dataswe\",\"wpcutzlvx\":\"datau\"}},\"bucketName\":\"dataolvedzrjkrpor\"}")
+ "{\"s3LinkedServiceName\":{\"referenceName\":\"emqetmo\",\"parameters\":{\"oyl\":\"datahhed\",\"sghbdvsorvhbygwt\":\"datacrldwcc\"}},\"bucketName\":\"dataxqlzzkbx\"}")
.toObject(RedshiftUnloadSettings.class);
- Assertions.assertEquals("snozjn", model.s3LinkedServiceName().referenceName());
+ Assertions.assertEquals("emqetmo", model.s3LinkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
RedshiftUnloadSettings model = new RedshiftUnloadSettings()
- .withS3LinkedServiceName(new LinkedServiceReference().withReferenceName("snozjn")
- .withParameters(
- mapOf("qxelmmxwmpziycns", "datacmhonojese", "kfofyfw", "dataswe", "wpcutzlvx", "datau")))
- .withBucketName("dataolvedzrjkrpor");
+ .withS3LinkedServiceName(new LinkedServiceReference().withReferenceName("emqetmo")
+ .withParameters(mapOf("oyl", "datahhed", "sghbdvsorvhbygwt", "datacrldwcc")))
+ .withBucketName("dataxqlzzkbx");
model = BinaryData.fromObject(model).toObject(RedshiftUnloadSettings.class);
- Assertions.assertEquals("snozjn", model.s3LinkedServiceName().referenceName());
+ Assertions.assertEquals("emqetmo", model.s3LinkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalSourceTests.java
index c92947880313..8ae76a3fe69d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalSourceTests.java
@@ -11,18 +11,18 @@ public final class RelationalSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RelationalSource model = BinaryData.fromString(
- "{\"type\":\"RelationalSource\",\"query\":\"datagqcwzytomnq\",\"additionalColumns\":\"datah\",\"sourceRetryCount\":\"datayvaoa\",\"sourceRetryWait\":\"datakyk\",\"maxConcurrentConnections\":\"dataqafnvjgix\",\"disableMetricsCollection\":\"datahinpy\",\"\":{\"fbnnhwpnloi\":\"datalllzsqolckwhg\",\"qwwzpbamcfr\":\"dataxzdohfvxavhfhl\",\"nrmbcklfpemgfv\":\"dataaytcygoom\"}}")
+ "{\"type\":\"RelationalSource\",\"query\":\"datarjooepfb\",\"additionalColumns\":\"databffxansgntjmnl\",\"sourceRetryCount\":\"datalrjdkyp\",\"sourceRetryWait\":\"datavilgn\",\"maxConcurrentConnections\":\"datatjbldgikokjwgej\",\"disableMetricsCollection\":\"datauzezwnqhcpkjgsy\",\"\":{\"rourtmccdejtoypl\":\"datatgwmqcutkk\"}}")
.toObject(RelationalSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RelationalSource model = new RelationalSource().withSourceRetryCount("datayvaoa")
- .withSourceRetryWait("datakyk")
- .withMaxConcurrentConnections("dataqafnvjgix")
- .withDisableMetricsCollection("datahinpy")
- .withQuery("datagqcwzytomnq")
- .withAdditionalColumns("datah");
+ RelationalSource model = new RelationalSource().withSourceRetryCount("datalrjdkyp")
+ .withSourceRetryWait("datavilgn")
+ .withMaxConcurrentConnections("datatjbldgikokjwgej")
+ .withDisableMetricsCollection("datauzezwnqhcpkjgsy")
+ .withQuery("datarjooepfb")
+ .withAdditionalColumns("databffxansgntjmnl");
model = BinaryData.fromObject(model).toObject(RelationalSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTests.java
index 48e824439129..fcb0214c6f21 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTests.java
@@ -19,31 +19,32 @@ public final class RelationalTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RelationalTableDataset model = BinaryData.fromString(
- "{\"type\":\"RelationalTable\",\"typeProperties\":{\"tableName\":\"dataxzizebjr\"},\"description\":\"gdstubw\",\"structure\":\"dataxzsshxliqmsckwh\",\"schema\":\"datadoi\",\"linkedServiceName\":{\"referenceName\":\"yobqzwjalwrsofxc\",\"parameters\":{\"mrs\":\"datamvj\",\"prel\":\"dataydl\",\"ztirjvqxvwkiocxo\":\"dataxfkz\"}},\"parameters\":{\"lrlqxbctatezyozd\":{\"type\":\"Float\",\"defaultValue\":\"datauocqflm\"}},\"annotations\":[\"dataqnl\",\"datajxcscnitodmrah\",\"datajido\",\"datanvlt\"],\"folder\":{\"name\":\"ahpuwkupbbnhic\"},\"\":{\"nhlsforsimtfcqm\":\"datazhrcqdfwbif\",\"pelpfijtezgxmpe\":\"dataynb\",\"f\":\"datazamadlerzi\",\"mirmnrijefmrt\":\"dataivczktllxswtdap\"}}")
+ "{\"type\":\"RelationalTable\",\"typeProperties\":{\"tableName\":\"datakxie\"},\"description\":\"lnml\",\"structure\":\"datafcnuestbsli\",\"schema\":\"datadnccotelik\",\"linkedServiceName\":{\"referenceName\":\"iytehhxtzxqdwbym\",\"parameters\":{\"ncrdo\":\"datan\",\"byh\":\"datactysecpekhx\",\"lfymtrts\":\"datatzcvimmwckoz\"}},\"parameters\":{\"rjschjxncqzah\":{\"type\":\"SecureString\",\"defaultValue\":\"datatzckjbcbkgnr\"},\"bimor\":{\"type\":\"Int\",\"defaultValue\":\"databgd\"}},\"annotations\":[\"dataxosgihtrxue\",\"databmxqfgvz\"],\"folder\":{\"name\":\"swshesgcsqose\"},\"\":{\"spfyvslazip\":\"datangoufpizpbmfx\",\"jtyc\":\"datalxgtdu\"}}")
.toObject(RelationalTableDataset.class);
- Assertions.assertEquals("gdstubw", model.description());
- Assertions.assertEquals("yobqzwjalwrsofxc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("lrlqxbctatezyozd").type());
- Assertions.assertEquals("ahpuwkupbbnhic", model.folder().name());
+ Assertions.assertEquals("lnml", model.description());
+ Assertions.assertEquals("iytehhxtzxqdwbym", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("rjschjxncqzah").type());
+ Assertions.assertEquals("swshesgcsqose", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RelationalTableDataset model = new RelationalTableDataset().withDescription("gdstubw")
- .withStructure("dataxzsshxliqmsckwh")
- .withSchema("datadoi")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("yobqzwjalwrsofxc")
- .withParameters(mapOf("mrs", "datamvj", "prel", "dataydl", "ztirjvqxvwkiocxo", "dataxfkz")))
- .withParameters(mapOf("lrlqxbctatezyozd",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datauocqflm")))
- .withAnnotations(Arrays.asList("dataqnl", "datajxcscnitodmrah", "datajido", "datanvlt"))
- .withFolder(new DatasetFolder().withName("ahpuwkupbbnhic"))
- .withTableName("dataxzizebjr");
+ RelationalTableDataset model = new RelationalTableDataset().withDescription("lnml")
+ .withStructure("datafcnuestbsli")
+ .withSchema("datadnccotelik")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("iytehhxtzxqdwbym")
+ .withParameters(mapOf("ncrdo", "datan", "byh", "datactysecpekhx", "lfymtrts", "datatzcvimmwckoz")))
+ .withParameters(mapOf("rjschjxncqzah",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datatzckjbcbkgnr"),
+ "bimor", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("databgd")))
+ .withAnnotations(Arrays.asList("dataxosgihtrxue", "databmxqfgvz"))
+ .withFolder(new DatasetFolder().withName("swshesgcsqose"))
+ .withTableName("datakxie");
model = BinaryData.fromObject(model).toObject(RelationalTableDataset.class);
- Assertions.assertEquals("gdstubw", model.description());
- Assertions.assertEquals("yobqzwjalwrsofxc", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("lrlqxbctatezyozd").type());
- Assertions.assertEquals("ahpuwkupbbnhic", model.folder().name());
+ Assertions.assertEquals("lnml", model.description());
+ Assertions.assertEquals("iytehhxtzxqdwbym", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("rjschjxncqzah").type());
+ Assertions.assertEquals("swshesgcsqose", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTypePropertiesTests.java
index cf0513c7b01b..b1399b6bcfff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RelationalTableDatasetTypePropertiesTests.java
@@ -10,13 +10,14 @@
public final class RelationalTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- RelationalTableDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datac\"}").toObject(RelationalTableDatasetTypeProperties.class);
+ RelationalTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datadrznlaxozqthkwxf\"}")
+ .toObject(RelationalTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RelationalTableDatasetTypeProperties model = new RelationalTableDatasetTypeProperties().withTableName("datac");
+ RelationalTableDatasetTypeProperties model
+ = new RelationalTableDatasetTypeProperties().withTableName("datadrznlaxozqthkwxf");
model = BinaryData.fromObject(model).toObject(RelationalTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTests.java
index f6aecafe0dc9..649d6c54eb2d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTests.java
@@ -14,26 +14,26 @@ public final class RerunTumblingWindowTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RerunTumblingWindowTrigger model = BinaryData.fromString(
- "{\"type\":\"RerunTumblingWindowTrigger\",\"typeProperties\":{\"parentTrigger\":\"dataplzr\",\"requestedStartTime\":\"2021-03-14T03:31:19Z\",\"requestedEndTime\":\"2021-09-21T15:16:39Z\",\"rerunConcurrency\":1544067436},\"description\":\"dqnefofujzwqpkhg\",\"runtimeState\":\"Disabled\",\"annotations\":[\"dataloerqkvufnphbzss\"],\"\":{\"vuhagoqxfxje\":\"datatrglpaocqxdvleou\",\"hrymeynbiwowu\":\"datauoquacrdn\"}}")
+ "{\"type\":\"RerunTumblingWindowTrigger\",\"typeProperties\":{\"parentTrigger\":\"datauhnh\",\"requestedStartTime\":\"2021-05-06T07:37:22Z\",\"requestedEndTime\":\"2021-01-01T04:14:19Z\",\"rerunConcurrency\":440558025},\"description\":\"fuukildlaytviw\",\"runtimeState\":\"Stopped\",\"annotations\":[\"datazk\",\"dataidps\",\"dataklmytaeallsxfz\",\"datantssbzm\"],\"\":{\"nhmxkgxrf\":\"dataj\"}}")
.toObject(RerunTumblingWindowTrigger.class);
- Assertions.assertEquals("dqnefofujzwqpkhg", model.description());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-14T03:31:19Z"), model.requestedStartTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-09-21T15:16:39Z"), model.requestedEndTime());
- Assertions.assertEquals(1544067436, model.rerunConcurrency());
+ Assertions.assertEquals("fuukildlaytviw", model.description());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-05-06T07:37:22Z"), model.requestedStartTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-01-01T04:14:19Z"), model.requestedEndTime());
+ Assertions.assertEquals(440558025, model.rerunConcurrency());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RerunTumblingWindowTrigger model = new RerunTumblingWindowTrigger().withDescription("dqnefofujzwqpkhg")
- .withAnnotations(Arrays.asList("dataloerqkvufnphbzss"))
- .withParentTrigger("dataplzr")
- .withRequestedStartTime(OffsetDateTime.parse("2021-03-14T03:31:19Z"))
- .withRequestedEndTime(OffsetDateTime.parse("2021-09-21T15:16:39Z"))
- .withRerunConcurrency(1544067436);
+ RerunTumblingWindowTrigger model = new RerunTumblingWindowTrigger().withDescription("fuukildlaytviw")
+ .withAnnotations(Arrays.asList("datazk", "dataidps", "dataklmytaeallsxfz", "datantssbzm"))
+ .withParentTrigger("datauhnh")
+ .withRequestedStartTime(OffsetDateTime.parse("2021-05-06T07:37:22Z"))
+ .withRequestedEndTime(OffsetDateTime.parse("2021-01-01T04:14:19Z"))
+ .withRerunConcurrency(440558025);
model = BinaryData.fromObject(model).toObject(RerunTumblingWindowTrigger.class);
- Assertions.assertEquals("dqnefofujzwqpkhg", model.description());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-14T03:31:19Z"), model.requestedStartTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-09-21T15:16:39Z"), model.requestedEndTime());
- Assertions.assertEquals(1544067436, model.rerunConcurrency());
+ Assertions.assertEquals("fuukildlaytviw", model.description());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-05-06T07:37:22Z"), model.requestedStartTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-01-01T04:14:19Z"), model.requestedEndTime());
+ Assertions.assertEquals(440558025, model.rerunConcurrency());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTypePropertiesTests.java
index 4f9bb37133ba..6306b16df53f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RerunTumblingWindowTriggerTypePropertiesTests.java
@@ -13,23 +13,23 @@ public final class RerunTumblingWindowTriggerTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RerunTumblingWindowTriggerTypeProperties model = BinaryData.fromString(
- "{\"parentTrigger\":\"datakiocjn\",\"requestedStartTime\":\"2021-03-21T01:55:32Z\",\"requestedEndTime\":\"2021-03-01T16:36:37Z\",\"rerunConcurrency\":1451711719}")
+ "{\"parentTrigger\":\"datamdpwpzuxo\",\"requestedStartTime\":\"2021-11-01T10:58:22Z\",\"requestedEndTime\":\"2021-05-15T01:16:29Z\",\"rerunConcurrency\":1024171923}")
.toObject(RerunTumblingWindowTriggerTypeProperties.class);
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-21T01:55:32Z"), model.requestedStartTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-01T16:36:37Z"), model.requestedEndTime());
- Assertions.assertEquals(1451711719, model.rerunConcurrency());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-11-01T10:58:22Z"), model.requestedStartTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-05-15T01:16:29Z"), model.requestedEndTime());
+ Assertions.assertEquals(1024171923, model.rerunConcurrency());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
RerunTumblingWindowTriggerTypeProperties model
- = new RerunTumblingWindowTriggerTypeProperties().withParentTrigger("datakiocjn")
- .withRequestedStartTime(OffsetDateTime.parse("2021-03-21T01:55:32Z"))
- .withRequestedEndTime(OffsetDateTime.parse("2021-03-01T16:36:37Z"))
- .withRerunConcurrency(1451711719);
+ = new RerunTumblingWindowTriggerTypeProperties().withParentTrigger("datamdpwpzuxo")
+ .withRequestedStartTime(OffsetDateTime.parse("2021-11-01T10:58:22Z"))
+ .withRequestedEndTime(OffsetDateTime.parse("2021-05-15T01:16:29Z"))
+ .withRerunConcurrency(1024171923);
model = BinaryData.fromObject(model).toObject(RerunTumblingWindowTriggerTypeProperties.class);
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-21T01:55:32Z"), model.requestedStartTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-01T16:36:37Z"), model.requestedEndTime());
- Assertions.assertEquals(1451711719, model.rerunConcurrency());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-11-01T10:58:22Z"), model.requestedStartTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-05-15T01:16:29Z"), model.requestedEndTime());
+ Assertions.assertEquals(1024171923, model.rerunConcurrency());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysObjectDatasetTests.java
index d5158f45829a..323958cc3f8f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysObjectDatasetTests.java
@@ -19,33 +19,32 @@ public final class ResponsysObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ResponsysObjectDataset model = BinaryData.fromString(
- "{\"type\":\"ResponsysObject\",\"typeProperties\":{\"tableName\":\"dataxcsdqoxhdenmj\"},\"description\":\"xgrggyciw\",\"structure\":\"dataqinr\",\"schema\":\"datavvmrn\",\"linkedServiceName\":{\"referenceName\":\"rdijox\",\"parameters\":{\"b\":\"datasychdcjggcmpncj\",\"owvfxe\":\"databnoq\",\"irvcpol\":\"datatzgwjeky\",\"ilbdvxlfhlzzgap\":\"datavgppp\"}},\"parameters\":{\"xnroyhthesyw\":{\"type\":\"SecureString\",\"defaultValue\":\"datablscrmzquuzywkgo\"}},\"annotations\":[\"datavg\"],\"folder\":{\"name\":\"c\"},\"\":{\"zyrgrlh\":\"datazcwuejmxlfzl\"}}")
+ "{\"type\":\"ResponsysObject\",\"typeProperties\":{\"tableName\":\"dataqxa\"},\"description\":\"mdmracfsffdralih\",\"structure\":\"datascygyzhcvlavyr\",\"schema\":\"datandxrmyzvtiojtpd\",\"linkedServiceName\":{\"referenceName\":\"u\",\"parameters\":{\"teccxfn\":\"dataxoyjyhutwedigiv\"}},\"parameters\":{\"bqpmfhjik\":{\"type\":\"Bool\",\"defaultValue\":\"dataca\"},\"hmyucgrmw\":{\"type\":\"Array\",\"defaultValue\":\"databdqitghnmelzvr\"}},\"annotations\":[\"datad\"],\"folder\":{\"name\":\"l\"},\"\":{\"pgtipaaoylwh\":\"dataqgrbrhhv\",\"ixdmoba\":\"datamkbweasgyp\",\"dqdchnzibixrgs\":\"dataydwqeuwdvcls\",\"gosijiqexqwqy\":\"datawxxqkwargcbg\"}}")
.toObject(ResponsysObjectDataset.class);
- Assertions.assertEquals("xgrggyciw", model.description());
- Assertions.assertEquals("rdijox", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("xnroyhthesyw").type());
- Assertions.assertEquals("c", model.folder().name());
+ Assertions.assertEquals("mdmracfsffdralih", model.description());
+ Assertions.assertEquals("u", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("bqpmfhjik").type());
+ Assertions.assertEquals("l", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ResponsysObjectDataset model = new ResponsysObjectDataset().withDescription("xgrggyciw")
- .withStructure("dataqinr")
- .withSchema("datavvmrn")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rdijox")
- .withParameters(mapOf("b", "datasychdcjggcmpncj", "owvfxe", "databnoq", "irvcpol", "datatzgwjeky",
- "ilbdvxlfhlzzgap", "datavgppp")))
- .withParameters(mapOf("xnroyhthesyw",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("datablscrmzquuzywkgo")))
- .withAnnotations(Arrays.asList("datavg"))
- .withFolder(new DatasetFolder().withName("c"))
- .withTableName("dataxcsdqoxhdenmj");
+ ResponsysObjectDataset model = new ResponsysObjectDataset().withDescription("mdmracfsffdralih")
+ .withStructure("datascygyzhcvlavyr")
+ .withSchema("datandxrmyzvtiojtpd")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("u")
+ .withParameters(mapOf("teccxfn", "dataxoyjyhutwedigiv")))
+ .withParameters(mapOf("bqpmfhjik",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataca"), "hmyucgrmw",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("databdqitghnmelzvr")))
+ .withAnnotations(Arrays.asList("datad"))
+ .withFolder(new DatasetFolder().withName("l"))
+ .withTableName("dataqxa");
model = BinaryData.fromObject(model).toObject(ResponsysObjectDataset.class);
- Assertions.assertEquals("xgrggyciw", model.description());
- Assertions.assertEquals("rdijox", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("xnroyhthesyw").type());
- Assertions.assertEquals("c", model.folder().name());
+ Assertions.assertEquals("mdmracfsffdralih", model.description());
+ Assertions.assertEquals("u", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("bqpmfhjik").type());
+ Assertions.assertEquals("l", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysSourceTests.java
index 3bfa7e30aa8b..c13399fdc831 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ResponsysSourceTests.java
@@ -11,19 +11,19 @@ public final class ResponsysSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ResponsysSource model = BinaryData.fromString(
- "{\"type\":\"ResponsysSource\",\"query\":\"datayjzferhxgstiawy\",\"queryTimeout\":\"datapqxujxbd\",\"additionalColumns\":\"datazplmlj\",\"sourceRetryCount\":\"datas\",\"sourceRetryWait\":\"datawsftytpjmu\",\"maxConcurrentConnections\":\"dataynhqlzantahuy\",\"disableMetricsCollection\":\"datasjympsxmoad\",\"\":{\"jvlzqsyvr\":\"datansmpfe\",\"bobx\":\"dataoleqikcorkem\"}}")
+ "{\"type\":\"ResponsysSource\",\"query\":\"datarapimtuojqzgyy\",\"queryTimeout\":\"dataywh\",\"additionalColumns\":\"datakjykvez\",\"sourceRetryCount\":\"datazt\",\"sourceRetryWait\":\"datahzkbmzldplam\",\"maxConcurrentConnections\":\"dataqljrnveqleozqq\",\"disableMetricsCollection\":\"dataawbw\",\"\":{\"ujsrlzw\":\"databuifhysatoplq\",\"ocowtoqfwbsbko\":\"dataqkprf\",\"mrset\":\"databdssjhwhfcxwrjbr\",\"espfgmosiskih\":\"datatulswajb\"}}")
.toObject(ResponsysSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ResponsysSource model = new ResponsysSource().withSourceRetryCount("datas")
- .withSourceRetryWait("datawsftytpjmu")
- .withMaxConcurrentConnections("dataynhqlzantahuy")
- .withDisableMetricsCollection("datasjympsxmoad")
- .withQueryTimeout("datapqxujxbd")
- .withAdditionalColumns("datazplmlj")
- .withQuery("datayjzferhxgstiawy");
+ ResponsysSource model = new ResponsysSource().withSourceRetryCount("datazt")
+ .withSourceRetryWait("datahzkbmzldplam")
+ .withMaxConcurrentConnections("dataqljrnveqleozqq")
+ .withDisableMetricsCollection("dataawbw")
+ .withQueryTimeout("dataywh")
+ .withAdditionalColumns("datakjykvez")
+ .withQuery("datarapimtuojqzgyy");
model = BinaryData.fromObject(model).toObject(ResponsysSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTests.java
index 1569ecca3e38..af8d26725e1a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTests.java
@@ -19,36 +19,36 @@ public final class RestResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RestResourceDataset model = BinaryData.fromString(
- "{\"type\":\"RestResource\",\"typeProperties\":{\"relativeUrl\":\"databbfpxxa\",\"requestMethod\":\"dataoz\",\"requestBody\":\"datagsnuhwy\",\"additionalHeaders\":{\"axcebnbeosk\":\"dataf\",\"v\":\"datamqqerwqxpj\",\"zmhytebjkjgee\":\"datamdfkhttuobr\"},\"paginationRules\":{\"twofxfmhlvy\":\"datafmabvbmn\"}},\"description\":\"sl\",\"structure\":\"datarml\",\"schema\":\"dataiekhjgqq\",\"linkedServiceName\":{\"referenceName\":\"ugwespscvsmsp\",\"parameters\":{\"upcvq\":\"datawozfvza\",\"cgmlmpn\":\"dataxcvwioqhc\"}},\"parameters\":{\"hdqseyp\":{\"type\":\"Array\",\"defaultValue\":\"dataiarz\"}},\"annotations\":[\"dataajpuyx\",\"dataa\",\"datarmzgccynb\",\"datavmsiehedm\"],\"folder\":{\"name\":\"neeyrxparxtz\"},\"\":{\"lzdssi\":\"datawddigebls\",\"p\":\"datawveeozbjkj\",\"dyw\":\"datazdnuehxwltss\"}}")
+ "{\"type\":\"RestResource\",\"typeProperties\":{\"relativeUrl\":\"dataaefe\",\"requestMethod\":\"datavkxdbnmcvaqy\",\"requestBody\":\"datazdobuesdyvfxnz\",\"additionalHeaders\":{\"dpsegivytabvbbk\":\"datafupktw\"},\"paginationRules\":{\"wuuqbmenxcqsxwc\":\"datawgsltutbuve\"}},\"description\":\"kcrudekkbnjre\",\"structure\":\"dataptedeuenthshnfi\",\"schema\":\"datapgpkkhpjnglaqlm\",\"linkedServiceName\":{\"referenceName\":\"h\",\"parameters\":{\"cpvfpnrzikvoxloe\":\"datardlpxiwwg\",\"hpxukxgoyxon\":\"datahyfivxdifbwbli\"}},\"parameters\":{\"qrrldxfua\":{\"type\":\"Array\",\"defaultValue\":\"datarxros\"},\"eyrqve\":{\"type\":\"Bool\",\"defaultValue\":\"datawxatktwjrppi\"}},\"annotations\":[\"datadcizhvksb\",\"datajklwjp\"],\"folder\":{\"name\":\"ncw\"},\"\":{\"uduiqoom\":\"datapyeyzolbfnflytf\",\"opwsnliyznghuq\":\"dataswkq\",\"dwrgavtfyzse\":\"datagpdglkf\"}}")
.toObject(RestResourceDataset.class);
- Assertions.assertEquals("sl", model.description());
- Assertions.assertEquals("ugwespscvsmsp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("hdqseyp").type());
- Assertions.assertEquals("neeyrxparxtz", model.folder().name());
+ Assertions.assertEquals("kcrudekkbnjre", model.description());
+ Assertions.assertEquals("h", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("qrrldxfua").type());
+ Assertions.assertEquals("ncw", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RestResourceDataset model = new RestResourceDataset().withDescription("sl")
- .withStructure("datarml")
- .withSchema("dataiekhjgqq")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ugwespscvsmsp")
- .withParameters(mapOf("upcvq", "datawozfvza", "cgmlmpn", "dataxcvwioqhc")))
- .withParameters(mapOf("hdqseyp",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataiarz")))
- .withAnnotations(Arrays.asList("dataajpuyx", "dataa", "datarmzgccynb", "datavmsiehedm"))
- .withFolder(new DatasetFolder().withName("neeyrxparxtz"))
- .withRelativeUrl("databbfpxxa")
- .withRequestMethod("dataoz")
- .withRequestBody("datagsnuhwy")
- .withAdditionalHeaders(
- mapOf("axcebnbeosk", "dataf", "v", "datamqqerwqxpj", "zmhytebjkjgee", "datamdfkhttuobr"))
- .withPaginationRules(mapOf("twofxfmhlvy", "datafmabvbmn"));
+ RestResourceDataset model = new RestResourceDataset().withDescription("kcrudekkbnjre")
+ .withStructure("dataptedeuenthshnfi")
+ .withSchema("datapgpkkhpjnglaqlm")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("h")
+ .withParameters(mapOf("cpvfpnrzikvoxloe", "datardlpxiwwg", "hpxukxgoyxon", "datahyfivxdifbwbli")))
+ .withParameters(mapOf("qrrldxfua",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datarxros"), "eyrqve",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datawxatktwjrppi")))
+ .withAnnotations(Arrays.asList("datadcizhvksb", "datajklwjp"))
+ .withFolder(new DatasetFolder().withName("ncw"))
+ .withRelativeUrl("dataaefe")
+ .withRequestMethod("datavkxdbnmcvaqy")
+ .withRequestBody("datazdobuesdyvfxnz")
+ .withAdditionalHeaders(mapOf("dpsegivytabvbbk", "datafupktw"))
+ .withPaginationRules(mapOf("wuuqbmenxcqsxwc", "datawgsltutbuve"));
model = BinaryData.fromObject(model).toObject(RestResourceDataset.class);
- Assertions.assertEquals("sl", model.description());
- Assertions.assertEquals("ugwespscvsmsp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("hdqseyp").type());
- Assertions.assertEquals("neeyrxparxtz", model.folder().name());
+ Assertions.assertEquals("kcrudekkbnjre", model.description());
+ Assertions.assertEquals("h", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("qrrldxfua").type());
+ Assertions.assertEquals("ncw", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTypePropertiesTests.java
index 5ff4b1725a4a..65f67a5a7a85 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestResourceDatasetTypePropertiesTests.java
@@ -13,19 +13,18 @@ public final class RestResourceDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RestResourceDatasetTypeProperties model = BinaryData.fromString(
- "{\"relativeUrl\":\"dataklgerxactsawv\",\"requestMethod\":\"dataimpthj\",\"requestBody\":\"dataplzmslubnk\",\"additionalHeaders\":{\"lfswarmybwmro\":\"datauysjhvrr\",\"cbfnxiajuv\":\"datageysyqnipehfw\"},\"paginationRules\":{\"zguaxfhvjixgofqd\":\"datafjisosfzlnraxnf\",\"jmi\":\"dataw\",\"ntlydprpensbmzj\":\"datauvrqpbxdoicqp\",\"hbfexmizz\":\"dataitukoy\"}}")
+ "{\"relativeUrl\":\"datam\",\"requestMethod\":\"datakryxpi\",\"requestBody\":\"dataapeakfdmcedl\",\"additionalHeaders\":{\"yoddoqkanqtrkicw\":\"datax\",\"wwmu\":\"dataqyrgqmndk\",\"kitlwgebylpz\":\"datahvifqeqfsrna\"},\"paginationRules\":{\"nilnijhwcbr\":\"datadaqwj\",\"npkbvzpk\":\"datasypo\"}}")
.toObject(RestResourceDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RestResourceDatasetTypeProperties model
- = new RestResourceDatasetTypeProperties().withRelativeUrl("dataklgerxactsawv")
- .withRequestMethod("dataimpthj")
- .withRequestBody("dataplzmslubnk")
- .withAdditionalHeaders(mapOf("lfswarmybwmro", "datauysjhvrr", "cbfnxiajuv", "datageysyqnipehfw"))
- .withPaginationRules(mapOf("zguaxfhvjixgofqd", "datafjisosfzlnraxnf", "jmi", "dataw", "ntlydprpensbmzj",
- "datauvrqpbxdoicqp", "hbfexmizz", "dataitukoy"));
+ RestResourceDatasetTypeProperties model = new RestResourceDatasetTypeProperties().withRelativeUrl("datam")
+ .withRequestMethod("datakryxpi")
+ .withRequestBody("dataapeakfdmcedl")
+ .withAdditionalHeaders(
+ mapOf("yoddoqkanqtrkicw", "datax", "wwmu", "dataqyrgqmndk", "kitlwgebylpz", "datahvifqeqfsrna"))
+ .withPaginationRules(mapOf("nilnijhwcbr", "datadaqwj", "npkbvzpk", "datasypo"));
model = BinaryData.fromObject(model).toObject(RestResourceDatasetTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSinkTests.java
index baf5b462842d..f42bee9068b7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSinkTests.java
@@ -11,23 +11,23 @@ public final class RestSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RestSink model = BinaryData.fromString(
- "{\"type\":\"RestSink\",\"requestMethod\":\"dataxxokif\",\"additionalHeaders\":\"datapwdyzsetrmvtq\",\"httpRequestTimeout\":\"datasoi\",\"requestInterval\":\"datacprkqywyb\",\"httpCompressionType\":\"dataayo\",\"writeBatchSize\":\"dataetzcxlisvqfb\",\"writeBatchTimeout\":\"dataizxp\",\"sinkRetryCount\":\"datapsaploex\",\"sinkRetryWait\":\"datamvlocd\",\"maxConcurrentConnections\":\"datahkob\",\"disableMetricsCollection\":\"datahhipn\",\"\":{\"n\":\"datadyriw\"}}")
+ "{\"type\":\"RestSink\",\"requestMethod\":\"datao\",\"additionalHeaders\":\"datarhlyhgii\",\"httpRequestTimeout\":\"datafa\",\"requestInterval\":\"dataobo\",\"httpCompressionType\":\"datapyilojwcza\",\"writeBatchSize\":\"datawtausk\",\"writeBatchTimeout\":\"datahhmtypgrkdmezaun\",\"sinkRetryCount\":\"datacqtigav\",\"sinkRetryWait\":\"datasnrjhjlploaeppl\",\"maxConcurrentConnections\":\"datakcazuj\",\"disableMetricsCollection\":\"datauuzbsxhivncue\",\"\":{\"rtlnzdk\":\"dataexcn\"}}")
.toObject(RestSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RestSink model = new RestSink().withWriteBatchSize("dataetzcxlisvqfb")
- .withWriteBatchTimeout("dataizxp")
- .withSinkRetryCount("datapsaploex")
- .withSinkRetryWait("datamvlocd")
- .withMaxConcurrentConnections("datahkob")
- .withDisableMetricsCollection("datahhipn")
- .withRequestMethod("dataxxokif")
- .withAdditionalHeaders("datapwdyzsetrmvtq")
- .withHttpRequestTimeout("datasoi")
- .withRequestInterval("datacprkqywyb")
- .withHttpCompressionType("dataayo");
+ RestSink model = new RestSink().withWriteBatchSize("datawtausk")
+ .withWriteBatchTimeout("datahhmtypgrkdmezaun")
+ .withSinkRetryCount("datacqtigav")
+ .withSinkRetryWait("datasnrjhjlploaeppl")
+ .withMaxConcurrentConnections("datakcazuj")
+ .withDisableMetricsCollection("datauuzbsxhivncue")
+ .withRequestMethod("datao")
+ .withAdditionalHeaders("datarhlyhgii")
+ .withHttpRequestTimeout("datafa")
+ .withRequestInterval("dataobo")
+ .withHttpCompressionType("datapyilojwcza");
model = BinaryData.fromObject(model).toObject(RestSink.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSourceTests.java
index 5d29548a3042..8ce83ff7075f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RestSourceTests.java
@@ -11,23 +11,23 @@ public final class RestSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
RestSource model = BinaryData.fromString(
- "{\"type\":\"RestSource\",\"requestMethod\":\"datadgmqscijlfulxg\",\"requestBody\":\"dataas\",\"additionalHeaders\":\"datamwsooq\",\"paginationRules\":\"datavplmyzebvgh\",\"httpRequestTimeout\":\"dataydehbvbexrbynnl\",\"requestInterval\":\"datad\",\"additionalColumns\":\"datak\",\"sourceRetryCount\":\"datazzsi\",\"sourceRetryWait\":\"databosacrnpscfkef\",\"maxConcurrentConnections\":\"datatxe\",\"disableMetricsCollection\":\"datamimgjuvjvtgece\",\"\":{\"oukfjwkctdn\":\"datanled\"}}")
+ "{\"type\":\"RestSource\",\"requestMethod\":\"datafeavz\",\"requestBody\":\"datammzisljxphwy\",\"additionalHeaders\":\"datamcpfrakucgjreoac\",\"paginationRules\":\"dataaboozxkdzmtkmn\",\"httpRequestTimeout\":\"datafdemrc\",\"requestInterval\":\"dataxgpkyetm\",\"additionalColumns\":\"datahihixisdvyflkeqg\",\"sourceRetryCount\":\"datajsbtosiwcve\",\"sourceRetryWait\":\"dataehbw\",\"maxConcurrentConnections\":\"dataoc\",\"disableMetricsCollection\":\"datazlfhhwdajfth\",\"\":{\"on\":\"datauomj\",\"qsniobehxxb\":\"datafq\"}}")
.toObject(RestSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RestSource model = new RestSource().withSourceRetryCount("datazzsi")
- .withSourceRetryWait("databosacrnpscfkef")
- .withMaxConcurrentConnections("datatxe")
- .withDisableMetricsCollection("datamimgjuvjvtgece")
- .withRequestMethod("datadgmqscijlfulxg")
- .withRequestBody("dataas")
- .withAdditionalHeaders("datamwsooq")
- .withPaginationRules("datavplmyzebvgh")
- .withHttpRequestTimeout("dataydehbvbexrbynnl")
- .withRequestInterval("datad")
- .withAdditionalColumns("datak");
+ RestSource model = new RestSource().withSourceRetryCount("datajsbtosiwcve")
+ .withSourceRetryWait("dataehbw")
+ .withMaxConcurrentConnections("dataoc")
+ .withDisableMetricsCollection("datazlfhhwdajfth")
+ .withRequestMethod("datafeavz")
+ .withRequestBody("datammzisljxphwy")
+ .withAdditionalHeaders("datamcpfrakucgjreoac")
+ .withPaginationRules("dataaboozxkdzmtkmn")
+ .withHttpRequestTimeout("datafdemrc")
+ .withRequestInterval("dataxgpkyetm")
+ .withAdditionalColumns("datahihixisdvyflkeqg");
model = BinaryData.fromObject(model).toObject(RestSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RetryPolicyTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RetryPolicyTests.java
index cd25ef573484..bcb171a6abb0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RetryPolicyTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/RetryPolicyTests.java
@@ -11,15 +11,15 @@
public final class RetryPolicyTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- RetryPolicy model = BinaryData.fromString("{\"count\":\"datavscg\",\"intervalInSeconds\":1440015104}")
+ RetryPolicy model = BinaryData.fromString("{\"count\":\"datapqlltoiud\",\"intervalInSeconds\":71196772}")
.toObject(RetryPolicy.class);
- Assertions.assertEquals(1440015104, model.intervalInSeconds());
+ Assertions.assertEquals(71196772, model.intervalInSeconds());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- RetryPolicy model = new RetryPolicy().withCount("datavscg").withIntervalInSeconds(1440015104);
+ RetryPolicy model = new RetryPolicy().withCount("datapqlltoiud").withIntervalInSeconds(71196772);
model = BinaryData.fromObject(model).toObject(RetryPolicy.class);
- Assertions.assertEquals(1440015104, model.intervalInSeconds());
+ Assertions.assertEquals(71196772, model.intervalInSeconds());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudObjectDatasetTests.java
index 41c48fd991fc..1b197b7d883a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudObjectDatasetTests.java
@@ -19,34 +19,41 @@ public final class SalesforceMarketingCloudObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceMarketingCloudObjectDataset model = BinaryData.fromString(
- "{\"type\":\"SalesforceMarketingCloudObject\",\"typeProperties\":{\"tableName\":\"dataktwomlpczlqboomz\"},\"description\":\"rolhsfddk\",\"structure\":\"datavevwxmnbw\",\"schema\":\"dataa\",\"linkedServiceName\":{\"referenceName\":\"xgnpyhtu\",\"parameters\":{\"aokex\":\"datapqild\"}},\"parameters\":{\"gtz\":{\"type\":\"String\",\"defaultValue\":\"datatkqjarlazb\"},\"oujfgtgxuupczegq\":{\"type\":\"Object\",\"defaultValue\":\"datatrm\"}},\"annotations\":[\"datadvssvg\",\"dataoggkztzttjnknpb\",\"datagzkuobclobn\",\"dataqe\"],\"folder\":{\"name\":\"liqlyugp\"},\"\":{\"yiqywlpxmli\":\"datazjmkffeonmnvmu\",\"ekbirhyvsyuv\":\"datatdegcrunbkilxs\",\"gio\":\"dataiemorszffiukltr\"}}")
+ "{\"type\":\"SalesforceMarketingCloudObject\",\"typeProperties\":{\"tableName\":\"dataesywywnvgy\"},\"description\":\"c\",\"structure\":\"datarzcw\",\"schema\":\"datajmxlfzl\",\"linkedServiceName\":{\"referenceName\":\"zyrgrlh\",\"parameters\":{\"vm\":\"dataaunjovlxq\",\"rgmnkgtlhzkrazk\":\"datazpniqwx\",\"eqzhehgvmm\":\"dataoiyecznvzmsvzng\"}},\"parameters\":{\"ypkfcdfuxi\":{\"type\":\"String\",\"defaultValue\":\"datanbnyplu\"},\"cdvhyefqhxyts\":{\"type\":\"String\",\"defaultValue\":\"dataxotnoil\"},\"ratqlreqbrc\":{\"type\":\"Int\",\"defaultValue\":\"datawcacwaaqakvokyax\"},\"babowrcyrnmj\":{\"type\":\"String\",\"defaultValue\":\"datatshzumxucz\"}},\"annotations\":[\"datawxqzkkagve\",\"datahmnaphrskmpeajz\"],\"folder\":{\"name\":\"avamzmzfntte\"},\"\":{\"pjdr\":\"datatxytja\",\"vbfaehjji\":\"datalijk\"}}")
.toObject(SalesforceMarketingCloudObjectDataset.class);
- Assertions.assertEquals("rolhsfddk", model.description());
- Assertions.assertEquals("xgnpyhtu", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("gtz").type());
- Assertions.assertEquals("liqlyugp", model.folder().name());
+ Assertions.assertEquals("c", model.description());
+ Assertions.assertEquals("zyrgrlh", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("ypkfcdfuxi").type());
+ Assertions.assertEquals("avamzmzfntte", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceMarketingCloudObjectDataset model = new SalesforceMarketingCloudObjectDataset()
- .withDescription("rolhsfddk")
- .withStructure("datavevwxmnbw")
- .withSchema("dataa")
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("xgnpyhtu").withParameters(mapOf("aokex", "datapqild")))
- .withParameters(mapOf("gtz",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datatkqjarlazb"),
- "oujfgtgxuupczegq",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datatrm")))
- .withAnnotations(Arrays.asList("datadvssvg", "dataoggkztzttjnknpb", "datagzkuobclobn", "dataqe"))
- .withFolder(new DatasetFolder().withName("liqlyugp"))
- .withTableName("dataktwomlpczlqboomz");
+ SalesforceMarketingCloudObjectDataset model
+ = new SalesforceMarketingCloudObjectDataset().withDescription("c")
+ .withStructure("datarzcw")
+ .withSchema("datajmxlfzl")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zyrgrlh")
+ .withParameters(mapOf("vm", "dataaunjovlxq", "rgmnkgtlhzkrazk", "datazpniqwx", "eqzhehgvmm",
+ "dataoiyecznvzmsvzng")))
+ .withParameters(
+ mapOf("ypkfcdfuxi",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datanbnyplu"),
+ "cdvhyefqhxyts",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataxotnoil"),
+ "ratqlreqbrc",
+ new ParameterSpecification().withType(ParameterType.INT)
+ .withDefaultValue("datawcacwaaqakvokyax"),
+ "babowrcyrnmj",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datatshzumxucz")))
+ .withAnnotations(Arrays.asList("datawxqzkkagve", "datahmnaphrskmpeajz"))
+ .withFolder(new DatasetFolder().withName("avamzmzfntte"))
+ .withTableName("dataesywywnvgy");
model = BinaryData.fromObject(model).toObject(SalesforceMarketingCloudObjectDataset.class);
- Assertions.assertEquals("rolhsfddk", model.description());
- Assertions.assertEquals("xgnpyhtu", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("gtz").type());
- Assertions.assertEquals("liqlyugp", model.folder().name());
+ Assertions.assertEquals("c", model.description());
+ Assertions.assertEquals("zyrgrlh", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("ypkfcdfuxi").type());
+ Assertions.assertEquals("avamzmzfntte", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudSourceTests.java
index 0870de24b3f4..6529a2177734 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceMarketingCloudSourceTests.java
@@ -11,20 +11,20 @@ public final class SalesforceMarketingCloudSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceMarketingCloudSource model = BinaryData.fromString(
- "{\"type\":\"SalesforceMarketingCloudSource\",\"query\":\"datay\",\"queryTimeout\":\"datakkipt\",\"additionalColumns\":\"datapwskckcwymfy\",\"sourceRetryCount\":\"datagvqioqrebwarljpl\",\"sourceRetryWait\":\"dataemxcdreqaqvs\",\"maxConcurrentConnections\":\"datayvearwt\",\"disableMetricsCollection\":\"databscwbiwvwmcrhy\",\"\":{\"n\":\"datatplmy\"}}")
+ "{\"type\":\"SalesforceMarketingCloudSource\",\"query\":\"dataokjwsszyetwoukdh\",\"queryTimeout\":\"dataerdggjihnz\",\"additionalColumns\":\"dataehgwgqgcnkgh\",\"sourceRetryCount\":\"datazjxouxigdwpgmh\",\"sourceRetryWait\":\"datavnexnw\",\"maxConcurrentConnections\":\"datawcxaqlym\",\"disableMetricsCollection\":\"datazv\",\"\":{\"lgkzgzxqwv\":\"dataecfyusfkcwfpoa\",\"bbd\":\"datafkqbgkssygdvl\",\"hpwpsx\":\"dataul\",\"bazbtyrjroqgnsf\":\"datagrniqnxps\"}}")
.toObject(SalesforceMarketingCloudSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SalesforceMarketingCloudSource model
- = new SalesforceMarketingCloudSource().withSourceRetryCount("datagvqioqrebwarljpl")
- .withSourceRetryWait("dataemxcdreqaqvs")
- .withMaxConcurrentConnections("datayvearwt")
- .withDisableMetricsCollection("databscwbiwvwmcrhy")
- .withQueryTimeout("datakkipt")
- .withAdditionalColumns("datapwskckcwymfy")
- .withQuery("datay");
+ = new SalesforceMarketingCloudSource().withSourceRetryCount("datazjxouxigdwpgmh")
+ .withSourceRetryWait("datavnexnw")
+ .withMaxConcurrentConnections("datawcxaqlym")
+ .withDisableMetricsCollection("datazv")
+ .withQueryTimeout("dataerdggjihnz")
+ .withAdditionalColumns("dataehgwgqgcnkgh")
+ .withQuery("dataokjwsszyetwoukdh");
model = BinaryData.fromObject(model).toObject(SalesforceMarketingCloudSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTests.java
index 0d72a7b52cd1..7dccc7d77060 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTests.java
@@ -19,32 +19,33 @@ public final class SalesforceObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceObjectDataset model = BinaryData.fromString(
- "{\"type\":\"SalesforceObject\",\"typeProperties\":{\"objectApiName\":\"datahgbgbhudh\"},\"description\":\"jimvrrq\",\"structure\":\"databpk\",\"schema\":\"dataamrlfizjuddnd\",\"linkedServiceName\":{\"referenceName\":\"hupngyhylqyafew\",\"parameters\":{\"xnxrqxrtzeargv\":\"datadxwuuy\"}},\"parameters\":{\"eignybffqc\":{\"type\":\"Int\",\"defaultValue\":\"datajhmvpjxsdh\"},\"tvmwgvconyse\":{\"type\":\"Bool\",\"defaultValue\":\"datanep\"}},\"annotations\":[\"datajfhpxnikouo\",\"datafalo\",\"databskkypor\",\"dataynieunbydlgfaphw\"],\"folder\":{\"name\":\"wtsaynrtvj\"},\"\":{\"hsdbfbm\":\"dataeeoxvqjmrnbl\",\"zmiaoaweacf\":\"dataivixzhpjg\"}}")
+ "{\"type\":\"SalesforceObject\",\"typeProperties\":{\"objectApiName\":\"dataxrltqmmijgpqfkwn\"},\"description\":\"ikczscymqfv\",\"structure\":\"datawpq\",\"schema\":\"dataumz\",\"linkedServiceName\":{\"referenceName\":\"pd\",\"parameters\":{\"zk\":\"datazvp\"}},\"parameters\":{\"wed\":{\"type\":\"Bool\",\"defaultValue\":\"datazbflbqmhbiyxx\"},\"lmsy\":{\"type\":\"SecureString\",\"defaultValue\":\"dataqbbseseayu\"},\"zk\":{\"type\":\"String\",\"defaultValue\":\"datacrolrzesbomp\"}},\"annotations\":[\"datanwjivtbusz\"],\"folder\":{\"name\":\"rdf\"},\"\":{\"sdeqngcaydzinlo\":\"dataywdal\",\"xrsi\":\"dataulpozmdahyc\"}}")
.toObject(SalesforceObjectDataset.class);
- Assertions.assertEquals("jimvrrq", model.description());
- Assertions.assertEquals("hupngyhylqyafew", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("eignybffqc").type());
- Assertions.assertEquals("wtsaynrtvj", model.folder().name());
+ Assertions.assertEquals("ikczscymqfv", model.description());
+ Assertions.assertEquals("pd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("wed").type());
+ Assertions.assertEquals("rdf", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceObjectDataset model = new SalesforceObjectDataset().withDescription("jimvrrq")
- .withStructure("databpk")
- .withSchema("dataamrlfizjuddnd")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hupngyhylqyafew")
- .withParameters(mapOf("xnxrqxrtzeargv", "datadxwuuy")))
- .withParameters(mapOf("eignybffqc",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datajhmvpjxsdh"),
- "tvmwgvconyse", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datanep")))
- .withAnnotations(Arrays.asList("datajfhpxnikouo", "datafalo", "databskkypor", "dataynieunbydlgfaphw"))
- .withFolder(new DatasetFolder().withName("wtsaynrtvj"))
- .withObjectApiName("datahgbgbhudh");
+ SalesforceObjectDataset model = new SalesforceObjectDataset().withDescription("ikczscymqfv")
+ .withStructure("datawpq")
+ .withSchema("dataumz")
+ .withLinkedServiceName(
+ new LinkedServiceReference().withReferenceName("pd").withParameters(mapOf("zk", "datazvp")))
+ .withParameters(mapOf("wed",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datazbflbqmhbiyxx"), "lmsy",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataqbbseseayu"),
+ "zk", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datacrolrzesbomp")))
+ .withAnnotations(Arrays.asList("datanwjivtbusz"))
+ .withFolder(new DatasetFolder().withName("rdf"))
+ .withObjectApiName("dataxrltqmmijgpqfkwn");
model = BinaryData.fromObject(model).toObject(SalesforceObjectDataset.class);
- Assertions.assertEquals("jimvrrq", model.description());
- Assertions.assertEquals("hupngyhylqyafew", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("eignybffqc").type());
- Assertions.assertEquals("wtsaynrtvj", model.folder().name());
+ Assertions.assertEquals("ikczscymqfv", model.description());
+ Assertions.assertEquals("pd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("wed").type());
+ Assertions.assertEquals("rdf", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTypePropertiesTests.java
index 2aaa58786aa3..49f504548b10 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceObjectDatasetTypePropertiesTests.java
@@ -10,15 +10,14 @@
public final class SalesforceObjectDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SalesforceObjectDatasetTypeProperties model
- = BinaryData.fromString("{\"objectApiName\":\"dataubuhruetcnxriqz\"}")
- .toObject(SalesforceObjectDatasetTypeProperties.class);
+ SalesforceObjectDatasetTypeProperties model = BinaryData.fromString("{\"objectApiName\":\"dataebldpo\"}")
+ .toObject(SalesforceObjectDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SalesforceObjectDatasetTypeProperties model
- = new SalesforceObjectDatasetTypeProperties().withObjectApiName("dataubuhruetcnxriqz");
+ = new SalesforceObjectDatasetTypeProperties().withObjectApiName("dataebldpo");
model = BinaryData.fromObject(model).toObject(SalesforceObjectDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTests.java
index 0448d6ebbf0c..70afea7c5c91 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTests.java
@@ -19,33 +19,35 @@ public final class SalesforceServiceCloudObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudObjectDataset model = BinaryData.fromString(
- "{\"type\":\"SalesforceServiceCloudObject\",\"typeProperties\":{\"objectApiName\":\"datak\"},\"description\":\"qdrrj\",\"structure\":\"datar\",\"schema\":\"datawobwxrxm\",\"linkedServiceName\":{\"referenceName\":\"okohlsfj\",\"parameters\":{\"huv\":\"dataqjpzhe\",\"dmjhymudjma\":\"dataqxqkv\"}},\"parameters\":{\"yqkaaptb\":{\"type\":\"Array\",\"defaultValue\":\"databhsermclyqwwu\"},\"bptw\":{\"type\":\"Array\",\"defaultValue\":\"datakb\"},\"u\":{\"type\":\"Bool\",\"defaultValue\":\"dataoc\"}},\"annotations\":[\"dataxzbnss\",\"datavqnpszbeuybut\",\"datadzjfjtvpeyxdyuxu\"],\"folder\":{\"name\":\"ltqmmij\"},\"\":{\"xgwpq\":\"datafkwnaeikczscymqf\",\"mzapdokez\":\"datay\",\"knfzqnzbflbqmhb\":\"datape\",\"ea\":\"datayxxvwedhagqbbse\"}}")
+ "{\"type\":\"SalesforceServiceCloudObject\",\"typeProperties\":{\"objectApiName\":\"datafj\"},\"description\":\"tnhrevimxmaxcj\",\"structure\":\"dataitygvdwds\",\"schema\":\"datatb\",\"linkedServiceName\":{\"referenceName\":\"kvuozbzchnqek\",\"parameters\":{\"kjse\":\"dataklpurlcydjh\",\"rdonkgobx\":\"datawiynd\"}},\"parameters\":{\"rswknpdrgnmza\":{\"type\":\"SecureString\",\"defaultValue\":\"datale\"},\"bk\":{\"type\":\"Object\",\"defaultValue\":\"dataoefqckievyrejyo\"},\"rovomep\":{\"type\":\"Bool\",\"defaultValue\":\"datausdwmnrtvvbucn\"}},\"annotations\":[\"dataicvwqzo\",\"datasfshe\",\"datanmsg\"],\"folder\":{\"name\":\"dibugvnrgalvwrhr\"},\"\":{\"vnpyeevffifujgtd\":\"datarbknuubxcwojtupq\",\"ybpchrtczwjcujyz\":\"datawlxmwefc\",\"i\":\"datavyrjqdjlgk\",\"n\":\"dataxxeuwiiirc\"}}")
.toObject(SalesforceServiceCloudObjectDataset.class);
- Assertions.assertEquals("qdrrj", model.description());
- Assertions.assertEquals("okohlsfj", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("yqkaaptb").type());
- Assertions.assertEquals("ltqmmij", model.folder().name());
+ Assertions.assertEquals("tnhrevimxmaxcj", model.description());
+ Assertions.assertEquals("kvuozbzchnqek", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("rswknpdrgnmza").type());
+ Assertions.assertEquals("dibugvnrgalvwrhr", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceServiceCloudObjectDataset model = new SalesforceServiceCloudObjectDataset().withDescription("qdrrj")
- .withStructure("datar")
- .withSchema("datawobwxrxm")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("okohlsfj")
- .withParameters(mapOf("huv", "dataqjpzhe", "dmjhymudjma", "dataqxqkv")))
- .withParameters(mapOf("yqkaaptb",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("databhsermclyqwwu"),
- "bptw", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datakb"), "u",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataoc")))
- .withAnnotations(Arrays.asList("dataxzbnss", "datavqnpszbeuybut", "datadzjfjtvpeyxdyuxu"))
- .withFolder(new DatasetFolder().withName("ltqmmij"))
- .withObjectApiName("datak");
+ SalesforceServiceCloudObjectDataset model
+ = new SalesforceServiceCloudObjectDataset().withDescription("tnhrevimxmaxcj")
+ .withStructure("dataitygvdwds")
+ .withSchema("datatb")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("kvuozbzchnqek")
+ .withParameters(mapOf("kjse", "dataklpurlcydjh", "rdonkgobx", "datawiynd")))
+ .withParameters(mapOf("rswknpdrgnmza",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datale"), "bk",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataoefqckievyrejyo"),
+ "rovomep",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datausdwmnrtvvbucn")))
+ .withAnnotations(Arrays.asList("dataicvwqzo", "datasfshe", "datanmsg"))
+ .withFolder(new DatasetFolder().withName("dibugvnrgalvwrhr"))
+ .withObjectApiName("datafj");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudObjectDataset.class);
- Assertions.assertEquals("qdrrj", model.description());
- Assertions.assertEquals("okohlsfj", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("yqkaaptb").type());
- Assertions.assertEquals("ltqmmij", model.folder().name());
+ Assertions.assertEquals("tnhrevimxmaxcj", model.description());
+ Assertions.assertEquals("kvuozbzchnqek", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("rswknpdrgnmza").type());
+ Assertions.assertEquals("dibugvnrgalvwrhr", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTypePropertiesTests.java
index 06283514f082..dbd3d1b8fe60 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudObjectDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class SalesforceServiceCloudObjectDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudObjectDatasetTypeProperties model
- = BinaryData.fromString("{\"objectApiName\":\"dataflmsy\"}")
+ = BinaryData.fromString("{\"objectApiName\":\"databdviwx\"}")
.toObject(SalesforceServiceCloudObjectDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SalesforceServiceCloudObjectDatasetTypeProperties model
- = new SalesforceServiceCloudObjectDatasetTypeProperties().withObjectApiName("dataflmsy");
+ = new SalesforceServiceCloudObjectDatasetTypeProperties().withObjectApiName("databdviwx");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudObjectDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSinkTests.java
index 38e4898abb30..ea3da4b61f68 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSinkTests.java
@@ -13,22 +13,22 @@ public final class SalesforceServiceCloudSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudSink model = BinaryData.fromString(
- "{\"type\":\"SalesforceServiceCloudSink\",\"writeBehavior\":\"Upsert\",\"externalIdFieldName\":\"datawriihwxc\",\"ignoreNullValues\":\"datayfgkrpjon\",\"writeBatchSize\":\"datansqjnuiiytyarp\",\"writeBatchTimeout\":\"dataigfdpp\",\"sinkRetryCount\":\"datakgdyg\",\"sinkRetryWait\":\"datadljgdy\",\"maxConcurrentConnections\":\"datartseznowzfxkofm\",\"disableMetricsCollection\":\"datawculsbn\",\"\":{\"ljx\":\"datafdzmrlprb\",\"jbasmrdpb\":\"datajaawnzzlfvefs\"}}")
+ "{\"type\":\"SalesforceServiceCloudSink\",\"writeBehavior\":\"Upsert\",\"externalIdFieldName\":\"datafl\",\"ignoreNullValues\":\"datagrnh\",\"writeBatchSize\":\"datasdmovbvnjyqqofdg\",\"writeBatchTimeout\":\"dataykc\",\"sinkRetryCount\":\"dataln\",\"sinkRetryWait\":\"datarggytyvox\",\"maxConcurrentConnections\":\"databyjg\",\"disableMetricsCollection\":\"datazjmukfwmhzarrft\",\"\":{\"vvab\":\"dataifrjgvhone\"}}")
.toObject(SalesforceServiceCloudSink.class);
Assertions.assertEquals(SalesforceSinkWriteBehavior.UPSERT, model.writeBehavior());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceServiceCloudSink model = new SalesforceServiceCloudSink().withWriteBatchSize("datansqjnuiiytyarp")
- .withWriteBatchTimeout("dataigfdpp")
- .withSinkRetryCount("datakgdyg")
- .withSinkRetryWait("datadljgdy")
- .withMaxConcurrentConnections("datartseznowzfxkofm")
- .withDisableMetricsCollection("datawculsbn")
+ SalesforceServiceCloudSink model = new SalesforceServiceCloudSink().withWriteBatchSize("datasdmovbvnjyqqofdg")
+ .withWriteBatchTimeout("dataykc")
+ .withSinkRetryCount("dataln")
+ .withSinkRetryWait("datarggytyvox")
+ .withMaxConcurrentConnections("databyjg")
+ .withDisableMetricsCollection("datazjmukfwmhzarrft")
.withWriteBehavior(SalesforceSinkWriteBehavior.UPSERT)
- .withExternalIdFieldName("datawriihwxc")
- .withIgnoreNullValues("datayfgkrpjon");
+ .withExternalIdFieldName("datafl")
+ .withIgnoreNullValues("datagrnh");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudSink.class);
Assertions.assertEquals(SalesforceSinkWriteBehavior.UPSERT, model.writeBehavior());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSourceTests.java
index 6649263b432d..f9bf1d4539db 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudSourceTests.java
@@ -11,20 +11,19 @@ public final class SalesforceServiceCloudSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudSource model = BinaryData.fromString(
- "{\"type\":\"SalesforceServiceCloudSource\",\"query\":\"datafafpyglnfwjs\",\"readBehavior\":\"datavexblucpmqwkfgm\",\"additionalColumns\":\"datavekstzqzhd\",\"sourceRetryCount\":\"datacajfersxnxlkcw\",\"sourceRetryWait\":\"dataejssksgxykdepqcy\",\"maxConcurrentConnections\":\"datahwsxpzkmotgmd\",\"disableMetricsCollection\":\"datawwqevbiuntp\",\"\":{\"qgywr\":\"datawjxlycelf\",\"ruldt\":\"datau\"}}")
+ "{\"type\":\"SalesforceServiceCloudSource\",\"query\":\"datajwiz\",\"readBehavior\":\"dataifz\",\"additionalColumns\":\"dataxtykjrdxlximvr\",\"sourceRetryCount\":\"datajja\",\"sourceRetryWait\":\"dataaskullvtsauj\",\"maxConcurrentConnections\":\"datahtz\",\"disableMetricsCollection\":\"datazqrpfhzxkjyg\",\"\":{\"jcozbnmthxcm\":\"datadgwdha\",\"exn\":\"dataq\",\"msmzykpnjgi\":\"datapvox\"}}")
.toObject(SalesforceServiceCloudSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceServiceCloudSource model
- = new SalesforceServiceCloudSource().withSourceRetryCount("datacajfersxnxlkcw")
- .withSourceRetryWait("dataejssksgxykdepqcy")
- .withMaxConcurrentConnections("datahwsxpzkmotgmd")
- .withDisableMetricsCollection("datawwqevbiuntp")
- .withQuery("datafafpyglnfwjs")
- .withReadBehavior("datavexblucpmqwkfgm")
- .withAdditionalColumns("datavekstzqzhd");
+ SalesforceServiceCloudSource model = new SalesforceServiceCloudSource().withSourceRetryCount("datajja")
+ .withSourceRetryWait("dataaskullvtsauj")
+ .withMaxConcurrentConnections("datahtz")
+ .withDisableMetricsCollection("datazqrpfhzxkjyg")
+ .withQuery("datajwiz")
+ .withReadBehavior("dataifz")
+ .withAdditionalColumns("dataxtykjrdxlximvr");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTests.java
index faf1a4a42bcc..7b08bcb1a6d4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTests.java
@@ -19,35 +19,33 @@ public final class SalesforceServiceCloudV2ObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudV2ObjectDataset model = BinaryData.fromString(
- "{\"type\":\"SalesforceServiceCloudV2Object\",\"typeProperties\":{\"objectApiName\":\"datazwncsjgfxvc\",\"reportId\":\"dataubyguq\"},\"description\":\"nmsvj\",\"structure\":\"datarpryyircbajxjr\",\"schema\":\"datayrkb\",\"linkedServiceName\":{\"referenceName\":\"atxkznlwlmbx\",\"parameters\":{\"kxiymzgrg\":\"dataevdayvx\",\"ybsps\":\"datajalrjwaezp\"}},\"parameters\":{\"suiwexpasckpg\":{\"type\":\"Bool\",\"defaultValue\":\"dataepzimfc\"},\"cmxtoejt\":{\"type\":\"Float\",\"defaultValue\":\"datayxbwslx\"},\"idkxz\":{\"type\":\"Int\",\"defaultValue\":\"datactm\"}},\"annotations\":[\"datauzntbpcadd\",\"datax\",\"datarxiperrplfm\",\"datavmjjfz\"],\"folder\":{\"name\":\"lbiqq\"},\"\":{\"symagbahdbtjmku\":\"datarxknfv\",\"bizrxhuq\":\"dataonrk\",\"cxgqtquirgopgza\":\"datavpanloqov\"}}")
+ "{\"type\":\"SalesforceServiceCloudV2Object\",\"typeProperties\":{\"objectApiName\":\"dataadzglm\",\"reportId\":\"datazpsuhsypxmul\"},\"description\":\"frerkqp\",\"structure\":\"datajxkbywsbu\",\"schema\":\"datamxbdjkmn\",\"linkedServiceName\":{\"referenceName\":\"sggnowx\",\"parameters\":{\"svghbtycvlkus\":\"datadbrd\",\"ype\":\"dataiikhrct\"}},\"parameters\":{\"sdvkym\":{\"type\":\"Bool\",\"defaultValue\":\"datardis\"}},\"annotations\":[\"datawmivoxgzegngl\"],\"folder\":{\"name\":\"fgazagh\"},\"\":{\"wxuxor\":\"datao\",\"lssolqypv\":\"datautuhvemg\",\"hvrkqv\":\"dataxlx\"}}")
.toObject(SalesforceServiceCloudV2ObjectDataset.class);
- Assertions.assertEquals("nmsvj", model.description());
- Assertions.assertEquals("atxkznlwlmbx", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("suiwexpasckpg").type());
- Assertions.assertEquals("lbiqq", model.folder().name());
+ Assertions.assertEquals("frerkqp", model.description());
+ Assertions.assertEquals("sggnowx", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("sdvkym").type());
+ Assertions.assertEquals("fgazagh", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SalesforceServiceCloudV2ObjectDataset model = new SalesforceServiceCloudV2ObjectDataset()
- .withDescription("nmsvj")
- .withStructure("datarpryyircbajxjr")
- .withSchema("datayrkb")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("atxkznlwlmbx")
- .withParameters(mapOf("kxiymzgrg", "dataevdayvx", "ybsps", "datajalrjwaezp")))
- .withParameters(mapOf("suiwexpasckpg",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataepzimfc"), "cmxtoejt",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datayxbwslx"), "idkxz",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datactm")))
- .withAnnotations(Arrays.asList("datauzntbpcadd", "datax", "datarxiperrplfm", "datavmjjfz"))
- .withFolder(new DatasetFolder().withName("lbiqq"))
- .withObjectApiName("datazwncsjgfxvc")
- .withReportId("dataubyguq");
+ .withDescription("frerkqp")
+ .withStructure("datajxkbywsbu")
+ .withSchema("datamxbdjkmn")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("sggnowx")
+ .withParameters(mapOf("svghbtycvlkus", "datadbrd", "ype", "dataiikhrct")))
+ .withParameters(
+ mapOf("sdvkym", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datardis")))
+ .withAnnotations(Arrays.asList("datawmivoxgzegngl"))
+ .withFolder(new DatasetFolder().withName("fgazagh"))
+ .withObjectApiName("dataadzglm")
+ .withReportId("datazpsuhsypxmul");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudV2ObjectDataset.class);
- Assertions.assertEquals("nmsvj", model.description());
- Assertions.assertEquals("atxkznlwlmbx", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("suiwexpasckpg").type());
- Assertions.assertEquals("lbiqq", model.folder().name());
+ Assertions.assertEquals("frerkqp", model.description());
+ Assertions.assertEquals("sggnowx", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("sdvkym").type());
+ Assertions.assertEquals("fgazagh", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTypePropertiesTests.java
index 17cc661e80d7..aaa077a3d877 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2ObjectDatasetTypePropertiesTests.java
@@ -11,15 +11,15 @@ public final class SalesforceServiceCloudV2ObjectDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudV2ObjectDatasetTypeProperties model
- = BinaryData.fromString("{\"objectApiName\":\"datacu\",\"reportId\":\"datajuzvyjxux\"}")
+ = BinaryData.fromString("{\"objectApiName\":\"datagd\",\"reportId\":\"datacvzfc\"}")
.toObject(SalesforceServiceCloudV2ObjectDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SalesforceServiceCloudV2ObjectDatasetTypeProperties model
- = new SalesforceServiceCloudV2ObjectDatasetTypeProperties().withObjectApiName("datacu")
- .withReportId("datajuzvyjxux");
+ = new SalesforceServiceCloudV2ObjectDatasetTypeProperties().withObjectApiName("datagd")
+ .withReportId("datacvzfc");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudV2ObjectDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SinkTests.java
index 337366b21827..d247eb5ffced 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SinkTests.java
@@ -13,24 +13,23 @@ public final class SalesforceServiceCloudV2SinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudV2Sink model = BinaryData.fromString(
- "{\"type\":\"SalesforceServiceCloudV2Sink\",\"writeBehavior\":\"Upsert\",\"externalIdFieldName\":\"datadlct\",\"ignoreNullValues\":\"datao\",\"writeBatchSize\":\"datavgrloshkqthuijvi\",\"writeBatchTimeout\":\"datawswpwbgoetu\",\"sinkRetryCount\":\"datasfsfuzqpigirnmd\",\"sinkRetryWait\":\"datamagmwyfxeu\",\"maxConcurrentConnections\":\"datavtkllbfnn\",\"disableMetricsCollection\":\"datar\",\"\":{\"wldkjayiexpcxylq\":\"dataqjcyhvyrhgeuvuj\",\"zxgha\":\"dataowunwactjpgwseul\",\"tjngkfipxolp\":\"datalrvpaumkz\"}}")
+ "{\"type\":\"SalesforceServiceCloudV2Sink\",\"writeBehavior\":\"Insert\",\"externalIdFieldName\":\"datan\",\"ignoreNullValues\":\"databwvaiiuq\",\"writeBatchSize\":\"dataaqoqjnvmfmrymk\",\"writeBatchTimeout\":\"datatorv\",\"sinkRetryCount\":\"datapjxdi\",\"sinkRetryWait\":\"datautdzhkbc\",\"maxConcurrentConnections\":\"dataav\",\"disableMetricsCollection\":\"datafmgtxzvy\",\"\":{\"bbjcznx\":\"datamlkrxjq\",\"yu\":\"datahiwaau\",\"onrrarznlr\":\"datajirtiubvyudk\"}}")
.toObject(SalesforceServiceCloudV2Sink.class);
- Assertions.assertEquals(SalesforceV2SinkWriteBehavior.UPSERT, model.writeBehavior());
+ Assertions.assertEquals(SalesforceV2SinkWriteBehavior.INSERT, model.writeBehavior());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceServiceCloudV2Sink model
- = new SalesforceServiceCloudV2Sink().withWriteBatchSize("datavgrloshkqthuijvi")
- .withWriteBatchTimeout("datawswpwbgoetu")
- .withSinkRetryCount("datasfsfuzqpigirnmd")
- .withSinkRetryWait("datamagmwyfxeu")
- .withMaxConcurrentConnections("datavtkllbfnn")
- .withDisableMetricsCollection("datar")
- .withWriteBehavior(SalesforceV2SinkWriteBehavior.UPSERT)
- .withExternalIdFieldName("datadlct")
- .withIgnoreNullValues("datao");
+ SalesforceServiceCloudV2Sink model = new SalesforceServiceCloudV2Sink().withWriteBatchSize("dataaqoqjnvmfmrymk")
+ .withWriteBatchTimeout("datatorv")
+ .withSinkRetryCount("datapjxdi")
+ .withSinkRetryWait("datautdzhkbc")
+ .withMaxConcurrentConnections("dataav")
+ .withDisableMetricsCollection("datafmgtxzvy")
+ .withWriteBehavior(SalesforceV2SinkWriteBehavior.INSERT)
+ .withExternalIdFieldName("datan")
+ .withIgnoreNullValues("databwvaiiuq");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudV2Sink.class);
- Assertions.assertEquals(SalesforceV2SinkWriteBehavior.UPSERT, model.writeBehavior());
+ Assertions.assertEquals(SalesforceV2SinkWriteBehavior.INSERT, model.writeBehavior());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SourceTests.java
index a0b6e0cf8b81..8e42e215005b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceServiceCloudV2SourceTests.java
@@ -11,20 +11,20 @@ public final class SalesforceServiceCloudV2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceServiceCloudV2Source model = BinaryData.fromString(
- "{\"type\":\"SalesforceServiceCloudV2Source\",\"SOQLQuery\":\"dataaqb\",\"query\":\"datacnbnlpp\",\"includeDeletedObjects\":\"databipfazsayrk\",\"additionalColumns\":\"datapnobcqnym\",\"sourceRetryCount\":\"datawr\",\"sourceRetryWait\":\"dataf\",\"maxConcurrentConnections\":\"datahu\",\"disableMetricsCollection\":\"datakxcnovkwvzrxaix\",\"\":{\"eivpuuvzyf\":\"dataes\",\"rrphtjljfmhgd\":\"datamorehpjaktszrc\"}}")
+ "{\"type\":\"SalesforceServiceCloudV2Source\",\"SOQLQuery\":\"datawvtimy\",\"query\":\"datadogn\",\"includeDeletedObjects\":\"datahvgow\",\"additionalColumns\":\"datakdjnszjiykwbyt\",\"sourceRetryCount\":\"datahcp\",\"sourceRetryWait\":\"datadv\",\"maxConcurrentConnections\":\"dataxv\",\"disableMetricsCollection\":\"dataezly\",\"\":{\"uz\":\"dataovcrmoalvea\",\"zrrikvyu\":\"dataezrajpedowmh\",\"cwbupxfikiumhv\":\"dataxnopdeqqf\",\"ilgamxnj\":\"dataxptqbwn\"}}")
.toObject(SalesforceServiceCloudV2Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceServiceCloudV2Source model = new SalesforceServiceCloudV2Source().withSourceRetryCount("datawr")
- .withSourceRetryWait("dataf")
- .withMaxConcurrentConnections("datahu")
- .withDisableMetricsCollection("datakxcnovkwvzrxaix")
- .withSoqlQuery("dataaqb")
- .withQuery("datacnbnlpp")
- .withIncludeDeletedObjects("databipfazsayrk")
- .withAdditionalColumns("datapnobcqnym");
+ SalesforceServiceCloudV2Source model = new SalesforceServiceCloudV2Source().withSourceRetryCount("datahcp")
+ .withSourceRetryWait("datadv")
+ .withMaxConcurrentConnections("dataxv")
+ .withDisableMetricsCollection("dataezly")
+ .withSoqlQuery("datawvtimy")
+ .withQuery("datadogn")
+ .withIncludeDeletedObjects("datahvgow")
+ .withAdditionalColumns("datakdjnszjiykwbyt");
model = BinaryData.fromObject(model).toObject(SalesforceServiceCloudV2Source.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSinkTests.java
index c57032e0e111..7f21ca3ba51e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSinkTests.java
@@ -13,22 +13,22 @@ public final class SalesforceSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceSink model = BinaryData.fromString(
- "{\"type\":\"SalesforceSink\",\"writeBehavior\":\"Insert\",\"externalIdFieldName\":\"datayxxwlyjdbsxjxl\",\"ignoreNullValues\":\"datas\",\"writeBatchSize\":\"datarolagbellp\",\"writeBatchTimeout\":\"datafbrsmyisndf\",\"sinkRetryCount\":\"datahgowhnvcqhmuv\",\"sinkRetryWait\":\"datastohurktod\",\"maxConcurrentConnections\":\"datartyijlvcmp\",\"disableMetricsCollection\":\"dataxx\",\"\":{\"ebw\":\"dataedbdkwzbkhvlsahj\",\"ihfxtbvhmsvcmce\":\"dataqnluszilkrcpxl\"}}")
+ "{\"type\":\"SalesforceSink\",\"writeBehavior\":\"Insert\",\"externalIdFieldName\":\"datag\",\"ignoreNullValues\":\"dataemocndb\",\"writeBatchSize\":\"dataxrkoxwyxodpcgdv\",\"writeBatchTimeout\":\"datan\",\"sinkRetryCount\":\"datavxdafilaizcdugn\",\"sinkRetryWait\":\"datamljgayka\",\"maxConcurrentConnections\":\"datankxoqecjznuqg\",\"disableMetricsCollection\":\"datavmuewshhq\",\"\":{\"liezf\":\"datac\",\"raksahw\":\"datatczzjfzjovwiz\",\"snb\":\"datapukltfknroxm\",\"fvqtvukcfesizkn\":\"datacz\"}}")
.toObject(SalesforceSink.class);
Assertions.assertEquals(SalesforceSinkWriteBehavior.INSERT, model.writeBehavior());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceSink model = new SalesforceSink().withWriteBatchSize("datarolagbellp")
- .withWriteBatchTimeout("datafbrsmyisndf")
- .withSinkRetryCount("datahgowhnvcqhmuv")
- .withSinkRetryWait("datastohurktod")
- .withMaxConcurrentConnections("datartyijlvcmp")
- .withDisableMetricsCollection("dataxx")
+ SalesforceSink model = new SalesforceSink().withWriteBatchSize("dataxrkoxwyxodpcgdv")
+ .withWriteBatchTimeout("datan")
+ .withSinkRetryCount("datavxdafilaizcdugn")
+ .withSinkRetryWait("datamljgayka")
+ .withMaxConcurrentConnections("datankxoqecjznuqg")
+ .withDisableMetricsCollection("datavmuewshhq")
.withWriteBehavior(SalesforceSinkWriteBehavior.INSERT)
- .withExternalIdFieldName("datayxxwlyjdbsxjxl")
- .withIgnoreNullValues("datas");
+ .withExternalIdFieldName("datag")
+ .withIgnoreNullValues("dataemocndb");
model = BinaryData.fromObject(model).toObject(SalesforceSink.class);
Assertions.assertEquals(SalesforceSinkWriteBehavior.INSERT, model.writeBehavior());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSourceTests.java
index dcd073322da3..6cce73c85700 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceSourceTests.java
@@ -11,20 +11,20 @@ public final class SalesforceSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceSource model = BinaryData.fromString(
- "{\"type\":\"SalesforceSource\",\"query\":\"dataglpynsblnwiw\",\"readBehavior\":\"databxe\",\"queryTimeout\":\"dataalhbrwaltvky\",\"additionalColumns\":\"datajopqtegkrjo\",\"sourceRetryCount\":\"dataaeg\",\"sourceRetryWait\":\"dataksscismrn\",\"maxConcurrentConnections\":\"dataklfibny\",\"disableMetricsCollection\":\"dataclxtfuo\",\"\":{\"zmfy\":\"datazbiu\",\"uqafolseyxp\":\"datavyzaofaiwlnfvexi\",\"gcj\":\"datakmlnjluay\"}}")
+ "{\"type\":\"SalesforceSource\",\"query\":\"dataaaoofltbsay\",\"readBehavior\":\"datawaejxzkqcmddc\",\"queryTimeout\":\"datanxyr\",\"additionalColumns\":\"dataegabsfjrjzdqscgo\",\"sourceRetryCount\":\"datagd\",\"sourceRetryWait\":\"dataepgfrb\",\"maxConcurrentConnections\":\"dataoeh\",\"disableMetricsCollection\":\"datawwsgqziwo\",\"\":{\"okckxfk\":\"datawjssyazmmbuxq\",\"qf\":\"datatqkbyruheawuc\",\"jguwts\":\"datarbtbogxlyvebv\"}}")
.toObject(SalesforceSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceSource model = new SalesforceSource().withSourceRetryCount("dataaeg")
- .withSourceRetryWait("dataksscismrn")
- .withMaxConcurrentConnections("dataklfibny")
- .withDisableMetricsCollection("dataclxtfuo")
- .withQueryTimeout("dataalhbrwaltvky")
- .withAdditionalColumns("datajopqtegkrjo")
- .withQuery("dataglpynsblnwiw")
- .withReadBehavior("databxe");
+ SalesforceSource model = new SalesforceSource().withSourceRetryCount("datagd")
+ .withSourceRetryWait("dataepgfrb")
+ .withMaxConcurrentConnections("dataoeh")
+ .withDisableMetricsCollection("datawwsgqziwo")
+ .withQueryTimeout("datanxyr")
+ .withAdditionalColumns("dataegabsfjrjzdqscgo")
+ .withQuery("dataaaoofltbsay")
+ .withReadBehavior("datawaejxzkqcmddc");
model = BinaryData.fromObject(model).toObject(SalesforceSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTests.java
index 6a21ed7ab49b..ccc54d67ffd0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTests.java
@@ -19,34 +19,38 @@ public final class SalesforceV2ObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceV2ObjectDataset model = BinaryData.fromString(
- "{\"type\":\"SalesforceV2Object\",\"typeProperties\":{\"objectApiName\":\"datap\",\"reportId\":\"datawsjpgb\"},\"description\":\"bxjh\",\"structure\":\"datatep\",\"schema\":\"dataunudmakkshrnaxk\",\"linkedServiceName\":{\"referenceName\":\"zkwohdigeyuocft\",\"parameters\":{\"vrnnbegrafeo\":\"dataodwqbaktvxerowu\",\"azhkqqsjkn\":\"datamtojxgdof\",\"zbwgpmdmwi\":\"dataq\",\"dargkwim\":\"dataevveswghhbqqhd\"}},\"parameters\":{\"irgkn\":{\"type\":\"Object\",\"defaultValue\":\"dataeuquuwczzcujwxvb\"},\"wdajyd\":{\"type\":\"String\",\"defaultValue\":\"datala\"}},\"annotations\":[\"datagipvspewyzhydt\"],\"folder\":{\"name\":\"trsdp\"},\"\":{\"eviccwbqysclwbj\":\"dataaigarmawokgc\",\"weofvsxauphzefi\":\"dataiynqryoi\",\"gtiivzkd\":\"dataeyydx\",\"ywmwtacrscfc\":\"dataexccwldgfq\"}}")
+ "{\"type\":\"SalesforceV2Object\",\"typeProperties\":{\"objectApiName\":\"dataalrjwaez\",\"reportId\":\"dataybsps\"},\"description\":\"mtcepzimfcfs\",\"structure\":\"datawexpasckpgbmly\",\"schema\":\"datawslxgcmxtoejtq\",\"linkedServiceName\":{\"referenceName\":\"qct\",\"parameters\":{\"zntbpcaddpxqrx\":\"datadkxzxol\",\"jfzizxl\":\"dataperrplfmfvm\"}},\"parameters\":{\"agbahdbtjmku\":{\"type\":\"Float\",\"defaultValue\":\"databarxknfvbsy\"},\"lo\":{\"type\":\"Object\",\"defaultValue\":\"datarklbizrxhuqfvpa\"},\"g\":{\"type\":\"Bool\",\"defaultValue\":\"datavcxgqtquirgo\"},\"uoqhqrcsksxqfhl\":{\"type\":\"SecureString\",\"defaultValue\":\"dataucujtjuzvyjxuxch\"}},\"annotations\":[\"datavdagvyjcdpncvfye\",\"datayodiij\",\"datasapqhipajsniv\",\"datamevljbcuwrfgpjfv\"],\"folder\":{\"name\":\"seodvlmdzgv\"},\"\":{\"crsm\":\"datazzugctygbbmumljv\",\"umnru\":\"dataojmxwc\",\"keqjftvltjop\":\"dataq\"}}")
.toObject(SalesforceV2ObjectDataset.class);
- Assertions.assertEquals("bxjh", model.description());
- Assertions.assertEquals("zkwohdigeyuocft", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("irgkn").type());
- Assertions.assertEquals("trsdp", model.folder().name());
+ Assertions.assertEquals("mtcepzimfcfs", model.description());
+ Assertions.assertEquals("qct", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("agbahdbtjmku").type());
+ Assertions.assertEquals("seodvlmdzgv", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceV2ObjectDataset model = new SalesforceV2ObjectDataset().withDescription("bxjh")
- .withStructure("datatep")
- .withSchema("dataunudmakkshrnaxk")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zkwohdigeyuocft")
- .withParameters(mapOf("vrnnbegrafeo", "dataodwqbaktvxerowu", "azhkqqsjkn", "datamtojxgdof",
- "zbwgpmdmwi", "dataq", "dargkwim", "dataevveswghhbqqhd")))
- .withParameters(mapOf("irgkn",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataeuquuwczzcujwxvb"),
- "wdajyd", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datala")))
- .withAnnotations(Arrays.asList("datagipvspewyzhydt"))
- .withFolder(new DatasetFolder().withName("trsdp"))
- .withObjectApiName("datap")
- .withReportId("datawsjpgb");
+ SalesforceV2ObjectDataset model = new SalesforceV2ObjectDataset().withDescription("mtcepzimfcfs")
+ .withStructure("datawexpasckpgbmly")
+ .withSchema("datawslxgcmxtoejtq")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qct")
+ .withParameters(mapOf("zntbpcaddpxqrx", "datadkxzxol", "jfzizxl", "dataperrplfmfvm")))
+ .withParameters(mapOf("agbahdbtjmku",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("databarxknfvbsy"), "lo",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datarklbizrxhuqfvpa"),
+ "g", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datavcxgqtquirgo"),
+ "uoqhqrcsksxqfhl",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("dataucujtjuzvyjxuxch")))
+ .withAnnotations(
+ Arrays.asList("datavdagvyjcdpncvfye", "datayodiij", "datasapqhipajsniv", "datamevljbcuwrfgpjfv"))
+ .withFolder(new DatasetFolder().withName("seodvlmdzgv"))
+ .withObjectApiName("dataalrjwaez")
+ .withReportId("dataybsps");
model = BinaryData.fromObject(model).toObject(SalesforceV2ObjectDataset.class);
- Assertions.assertEquals("bxjh", model.description());
- Assertions.assertEquals("zkwohdigeyuocft", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("irgkn").type());
- Assertions.assertEquals("trsdp", model.folder().name());
+ Assertions.assertEquals("mtcepzimfcfs", model.description());
+ Assertions.assertEquals("qct", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("agbahdbtjmku").type());
+ Assertions.assertEquals("seodvlmdzgv", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTypePropertiesTests.java
index 2c63afa9c3f8..4e0683c0878f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2ObjectDatasetTypePropertiesTests.java
@@ -11,15 +11,15 @@ public final class SalesforceV2ObjectDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceV2ObjectDatasetTypeProperties model
- = BinaryData.fromString("{\"objectApiName\":\"datar\",\"reportId\":\"datacullmfwfpoeow\"}")
+ = BinaryData.fromString("{\"objectApiName\":\"datavpkbz\",\"reportId\":\"datanowpajfhxsmu\"}")
.toObject(SalesforceV2ObjectDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SalesforceV2ObjectDatasetTypeProperties model
- = new SalesforceV2ObjectDatasetTypeProperties().withObjectApiName("datar")
- .withReportId("datacullmfwfpoeow");
+ = new SalesforceV2ObjectDatasetTypeProperties().withObjectApiName("datavpkbz")
+ .withReportId("datanowpajfhxsmu");
model = BinaryData.fromObject(model).toObject(SalesforceV2ObjectDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SinkTests.java
index 8a4646974edf..35e377b513ff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SinkTests.java
@@ -13,23 +13,23 @@ public final class SalesforceV2SinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceV2Sink model = BinaryData.fromString(
- "{\"type\":\"SalesforceV2Sink\",\"writeBehavior\":\"Insert\",\"externalIdFieldName\":\"datagddgpqfflswqe\",\"ignoreNullValues\":\"datafr\",\"writeBatchSize\":\"dataqeinnbukevty\",\"writeBatchTimeout\":\"dataxosszqu\",\"sinkRetryCount\":\"datawklsthjvykewpgw\",\"sinkRetryWait\":\"datalrt\",\"maxConcurrentConnections\":\"dataeuorojrnkxswoh\",\"disableMetricsCollection\":\"datancdd\",\"\":{\"dhh\":\"dataitntd\"}}")
+ "{\"type\":\"SalesforceV2Sink\",\"writeBehavior\":\"Upsert\",\"externalIdFieldName\":\"datansbbhd\",\"ignoreNullValues\":\"dataegllc\",\"writeBatchSize\":\"dataihy\",\"writeBatchTimeout\":\"datagukf\",\"sinkRetryCount\":\"dataqokzvxknygimohrl\",\"sinkRetryWait\":\"datajyxhwvnyupszchq\",\"maxConcurrentConnections\":\"dataudd\",\"disableMetricsCollection\":\"datazvsmnxb\",\"\":{\"mgfwdxukmeo\":\"dataib\"}}")
.toObject(SalesforceV2Sink.class);
- Assertions.assertEquals(SalesforceV2SinkWriteBehavior.INSERT, model.writeBehavior());
+ Assertions.assertEquals(SalesforceV2SinkWriteBehavior.UPSERT, model.writeBehavior());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceV2Sink model = new SalesforceV2Sink().withWriteBatchSize("dataqeinnbukevty")
- .withWriteBatchTimeout("dataxosszqu")
- .withSinkRetryCount("datawklsthjvykewpgw")
- .withSinkRetryWait("datalrt")
- .withMaxConcurrentConnections("dataeuorojrnkxswoh")
- .withDisableMetricsCollection("datancdd")
- .withWriteBehavior(SalesforceV2SinkWriteBehavior.INSERT)
- .withExternalIdFieldName("datagddgpqfflswqe")
- .withIgnoreNullValues("datafr");
+ SalesforceV2Sink model = new SalesforceV2Sink().withWriteBatchSize("dataihy")
+ .withWriteBatchTimeout("datagukf")
+ .withSinkRetryCount("dataqokzvxknygimohrl")
+ .withSinkRetryWait("datajyxhwvnyupszchq")
+ .withMaxConcurrentConnections("dataudd")
+ .withDisableMetricsCollection("datazvsmnxb")
+ .withWriteBehavior(SalesforceV2SinkWriteBehavior.UPSERT)
+ .withExternalIdFieldName("datansbbhd")
+ .withIgnoreNullValues("dataegllc");
model = BinaryData.fromObject(model).toObject(SalesforceV2Sink.class);
- Assertions.assertEquals(SalesforceV2SinkWriteBehavior.INSERT, model.writeBehavior());
+ Assertions.assertEquals(SalesforceV2SinkWriteBehavior.UPSERT, model.writeBehavior());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SourceTests.java
index 771eafdbbd22..cec666bee7f0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SalesforceV2SourceTests.java
@@ -11,21 +11,22 @@ public final class SalesforceV2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SalesforceV2Source model = BinaryData.fromString(
- "{\"type\":\"SalesforceV2Source\",\"SOQLQuery\":\"dataero\",\"query\":\"datanvjouzjkjxbraqz\",\"includeDeletedObjects\":\"datavogfmpdlm\",\"queryTimeout\":\"datanlqnklbwyqoyp\",\"additionalColumns\":\"datar\",\"sourceRetryCount\":\"datajxmgxsp\",\"sourceRetryWait\":\"dataerokbdkwvjo\",\"maxConcurrentConnections\":\"dataoaiydjgkdjmyl\",\"disableMetricsCollection\":\"datajxjcloyvr\",\"\":{\"afklbkigzvugwbc\":\"datapnlwuhtfa\",\"ixp\":\"dataabsqpttulhanjui\",\"sk\":\"datatfdujuoiien\"}}")
+ "{\"type\":\"SalesforceV2Source\",\"SOQLQuery\":\"datahzfjmnaby\",\"query\":\"datachhkwlmittpbi\",\"includeDeletedObjects\":\"datakdxhnvyb\",\"pageSize\":\"datalbdazsjbgvdzz\",\"queryTimeout\":\"datahlwvvhovkad\",\"additionalColumns\":\"datahgbtnle\",\"sourceRetryCount\":\"datadah\",\"sourceRetryWait\":\"dataijvikpgzkfjqob\",\"maxConcurrentConnections\":\"datajlrvxryjxjdlg\",\"disableMetricsCollection\":\"datanjalccix\",\"\":{\"jznzgmfufszvsji\":\"datazgbuhcrwqrf\",\"lcqaafuwxeho\":\"datajve\",\"q\":\"dataazbgcbd\"}}")
.toObject(SalesforceV2Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SalesforceV2Source model = new SalesforceV2Source().withSourceRetryCount("datajxmgxsp")
- .withSourceRetryWait("dataerokbdkwvjo")
- .withMaxConcurrentConnections("dataoaiydjgkdjmyl")
- .withDisableMetricsCollection("datajxjcloyvr")
- .withQueryTimeout("datanlqnklbwyqoyp")
- .withAdditionalColumns("datar")
- .withSoqlQuery("dataero")
- .withQuery("datanvjouzjkjxbraqz")
- .withIncludeDeletedObjects("datavogfmpdlm");
+ SalesforceV2Source model = new SalesforceV2Source().withSourceRetryCount("datadah")
+ .withSourceRetryWait("dataijvikpgzkfjqob")
+ .withMaxConcurrentConnections("datajlrvxryjxjdlg")
+ .withDisableMetricsCollection("datanjalccix")
+ .withQueryTimeout("datahlwvvhovkad")
+ .withAdditionalColumns("datahgbtnle")
+ .withSoqlQuery("datahzfjmnaby")
+ .withQuery("datachhkwlmittpbi")
+ .withIncludeDeletedObjects("datakdxhnvyb")
+ .withPageSize("datalbdazsjbgvdzz");
model = BinaryData.fromObject(model).toObject(SalesforceV2Source.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwCubeDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwCubeDatasetTests.java
index 7ff7abcf15e1..f62e908a0b24 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwCubeDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwCubeDatasetTests.java
@@ -19,34 +19,33 @@ public final class SapBwCubeDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapBwCubeDataset model = BinaryData.fromString(
- "{\"type\":\"SapBwCube\",\"description\":\"shennmsgpywdib\",\"structure\":\"datavnrgalv\",\"schema\":\"datahry\",\"linkedServiceName\":{\"referenceName\":\"brbknuubxcwoj\",\"parameters\":{\"fujgtdowlxm\":\"dataqdvnpyeevff\"}},\"parameters\":{\"vyrjqdjlgk\":{\"type\":\"String\",\"defaultValue\":\"dataybpchrtczwjcujyz\"},\"n\":{\"type\":\"SecureString\",\"defaultValue\":\"dataxxeuwiiirc\"},\"ohktxagfujdbqjny\":{\"type\":\"String\",\"defaultValue\":\"datadviw\"}},\"annotations\":[\"datavxgxqqqa\",\"datafeoo\",\"dataftpvevtarp\",\"dataklqlii\"],\"folder\":{\"name\":\"n\"},\"\":{\"gijydg\":\"datajno\"}}")
+ "{\"type\":\"SapBwCube\",\"description\":\"pu\",\"structure\":\"dataa\",\"schema\":\"datasujtgg\",\"linkedServiceName\":{\"referenceName\":\"bszam\",\"parameters\":{\"lrnhhjtvhqsz\":\"dataejpdcliqwzutiy\",\"dp\":\"datasyovqmqc\"}},\"parameters\":{\"kjthl\":{\"type\":\"Object\",\"defaultValue\":\"datanf\"},\"wfubk\":{\"type\":\"String\",\"defaultValue\":\"dataxw\"},\"uktdrsjtmnkxjouw\":{\"type\":\"Int\",\"defaultValue\":\"datajjxumowynjmoozm\"}},\"annotations\":[\"datafdt\",\"datatia\"],\"folder\":{\"name\":\"rnuhcfhepisqbc\"},\"\":{\"blcyeqdobobaq\":\"dataoiommemsoq\",\"srsixwn\":\"dataabebckc\",\"qyyfrridzfpsfyak\":\"datapjcxbjgfm\"}}")
.toObject(SapBwCubeDataset.class);
- Assertions.assertEquals("shennmsgpywdib", model.description());
- Assertions.assertEquals("brbknuubxcwoj", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("vyrjqdjlgk").type());
- Assertions.assertEquals("n", model.folder().name());
+ Assertions.assertEquals("pu", model.description());
+ Assertions.assertEquals("bszam", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("kjthl").type());
+ Assertions.assertEquals("rnuhcfhepisqbc", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapBwCubeDataset model = new SapBwCubeDataset().withDescription("shennmsgpywdib")
- .withStructure("datavnrgalv")
- .withSchema("datahry")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("brbknuubxcwoj")
- .withParameters(mapOf("fujgtdowlxm", "dataqdvnpyeevff")))
- .withParameters(mapOf("vyrjqdjlgk",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataybpchrtczwjcujyz"),
- "n",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataxxeuwiiirc"),
- "ohktxagfujdbqjny",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datadviw")))
- .withAnnotations(Arrays.asList("datavxgxqqqa", "datafeoo", "dataftpvevtarp", "dataklqlii"))
- .withFolder(new DatasetFolder().withName("n"));
+ SapBwCubeDataset model = new SapBwCubeDataset().withDescription("pu")
+ .withStructure("dataa")
+ .withSchema("datasujtgg")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bszam")
+ .withParameters(mapOf("lrnhhjtvhqsz", "dataejpdcliqwzutiy", "dp", "datasyovqmqc")))
+ .withParameters(
+ mapOf("kjthl", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datanf"),
+ "wfubk", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataxw"),
+ "uktdrsjtmnkxjouw",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datajjxumowynjmoozm")))
+ .withAnnotations(Arrays.asList("datafdt", "datatia"))
+ .withFolder(new DatasetFolder().withName("rnuhcfhepisqbc"));
model = BinaryData.fromObject(model).toObject(SapBwCubeDataset.class);
- Assertions.assertEquals("shennmsgpywdib", model.description());
- Assertions.assertEquals("brbknuubxcwoj", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("vyrjqdjlgk").type());
- Assertions.assertEquals("n", model.folder().name());
+ Assertions.assertEquals("pu", model.description());
+ Assertions.assertEquals("bszam", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("kjthl").type());
+ Assertions.assertEquals("rnuhcfhepisqbc", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwSourceTests.java
index ed00775dfa20..72294564d3ac 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapBwSourceTests.java
@@ -11,19 +11,19 @@ public final class SapBwSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapBwSource model = BinaryData.fromString(
- "{\"type\":\"SapBwSource\",\"query\":\"dataprf\",\"queryTimeout\":\"datahfv\",\"additionalColumns\":\"datayqzhoikemhohxa\",\"sourceRetryCount\":\"dataxoowpoogozer\",\"sourceRetryWait\":\"datazvpbnkgkuujeqqjq\",\"maxConcurrentConnections\":\"datajkajlogvfnwq\",\"disableMetricsCollection\":\"datalvazkqkycg\",\"\":{\"c\":\"datawehjybboqyxi\"}}")
+ "{\"type\":\"SapBwSource\",\"query\":\"datacnk\",\"queryTimeout\":\"datamiecfmqc\",\"additionalColumns\":\"datapcdbvcxo\",\"sourceRetryCount\":\"datahefuhnbdl\",\"sourceRetryWait\":\"datawectz\",\"maxConcurrentConnections\":\"datagvcbt\",\"disableMetricsCollection\":\"datampnkyvujhej\",\"\":{\"nbqhmuqyz\":\"datavlguysbrn\",\"ffdaxlyhxpdq\":\"datakormrcjshtcfn\"}}")
.toObject(SapBwSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapBwSource model = new SapBwSource().withSourceRetryCount("dataxoowpoogozer")
- .withSourceRetryWait("datazvpbnkgkuujeqqjq")
- .withMaxConcurrentConnections("datajkajlogvfnwq")
- .withDisableMetricsCollection("datalvazkqkycg")
- .withQueryTimeout("datahfv")
- .withAdditionalColumns("datayqzhoikemhohxa")
- .withQuery("dataprf");
+ SapBwSource model = new SapBwSource().withSourceRetryCount("datahefuhnbdl")
+ .withSourceRetryWait("datawectz")
+ .withMaxConcurrentConnections("datagvcbt")
+ .withDisableMetricsCollection("datampnkyvujhej")
+ .withQueryTimeout("datamiecfmqc")
+ .withAdditionalColumns("datapcdbvcxo")
+ .withQuery("datacnk");
model = BinaryData.fromObject(model).toObject(SapBwSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTests.java
index be5c29690ca8..ef2686eac14d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTests.java
@@ -19,34 +19,37 @@ public final class SapCloudForCustomerResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapCloudForCustomerResourceDataset model = BinaryData.fromString(
- "{\"type\":\"SapCloudForCustomerResource\",\"typeProperties\":{\"path\":\"dataebjuymtevaebzm\"},\"description\":\"whrjkejvaedogzo\",\"structure\":\"dataxbxxgjogcphivfhr\",\"schema\":\"dataenfdvdoea\",\"linkedServiceName\":{\"referenceName\":\"ywusrjzhdtr\",\"parameters\":{\"wnmwtqiljknn\":\"dataezfsmyljdzyy\",\"aqjyih\":\"dataynkstdtfwhjfphf\",\"vhkhpsp\":\"datacwwvaosckf\",\"exnguwnrdpuz\":\"dataweifdyfa\"}},\"parameters\":{\"ybsz\":{\"type\":\"Array\",\"defaultValue\":\"dataujtg\"},\"yelrnh\":{\"type\":\"Array\",\"defaultValue\":\"datajxejpdcliqwzut\"}},\"annotations\":[\"datavhqsz\"],\"folder\":{\"name\":\"ovqmqcudptoqwr\"},\"\":{\"kmxwawfu\":\"datakjthl\"}}")
+ "{\"type\":\"SapCloudForCustomerResource\",\"typeProperties\":{\"path\":\"datadfhmlx\"},\"description\":\"keknumkqafzv\",\"structure\":\"datariysjrgt\",\"schema\":\"datawpuqpsrc\",\"linkedServiceName\":{\"referenceName\":\"kdvvoydwedggwg\",\"parameters\":{\"drjbjngoars\":\"databwatz\"}},\"parameters\":{\"rqw\":{\"type\":\"Float\",\"defaultValue\":\"dataemzcyniapypimrx\"},\"stuinytkmlfupjzc\":{\"type\":\"Object\",\"defaultValue\":\"datae\"},\"yxjg\":{\"type\":\"Array\",\"defaultValue\":\"datazj\"}},\"annotations\":[\"datauerrdaktnytkbc\",\"datarfcvcp\"],\"folder\":{\"name\":\"j\"},\"\":{\"vlhnhhcikhleb\":\"datapw\",\"giflr\":\"datajgylsac\"}}")
.toObject(SapCloudForCustomerResourceDataset.class);
- Assertions.assertEquals("whrjkejvaedogzo", model.description());
- Assertions.assertEquals("ywusrjzhdtr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ybsz").type());
- Assertions.assertEquals("ovqmqcudptoqwr", model.folder().name());
+ Assertions.assertEquals("keknumkqafzv", model.description());
+ Assertions.assertEquals("kdvvoydwedggwg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("rqw").type());
+ Assertions.assertEquals("j", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SapCloudForCustomerResourceDataset model
- = new SapCloudForCustomerResourceDataset().withDescription("whrjkejvaedogzo")
- .withStructure("dataxbxxgjogcphivfhr")
- .withSchema("dataenfdvdoea")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ywusrjzhdtr")
- .withParameters(mapOf("wnmwtqiljknn", "dataezfsmyljdzyy", "aqjyih", "dataynkstdtfwhjfphf",
- "vhkhpsp", "datacwwvaosckf", "exnguwnrdpuz", "dataweifdyfa")))
- .withParameters(mapOf("ybsz",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataujtg"), "yelrnh",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datajxejpdcliqwzut")))
- .withAnnotations(Arrays.asList("datavhqsz"))
- .withFolder(new DatasetFolder().withName("ovqmqcudptoqwr"))
- .withPath("dataebjuymtevaebzm");
+ = new SapCloudForCustomerResourceDataset().withDescription("keknumkqafzv")
+ .withStructure("datariysjrgt")
+ .withSchema("datawpuqpsrc")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("kdvvoydwedggwg")
+ .withParameters(mapOf("drjbjngoars", "databwatz")))
+ .withParameters(
+ mapOf("rqw",
+ new ParameterSpecification().withType(ParameterType.FLOAT)
+ .withDefaultValue("dataemzcyniapypimrx"),
+ "stuinytkmlfupjzc",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datae"), "yxjg",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datazj")))
+ .withAnnotations(Arrays.asList("datauerrdaktnytkbc", "datarfcvcp"))
+ .withFolder(new DatasetFolder().withName("j"))
+ .withPath("datadfhmlx");
model = BinaryData.fromObject(model).toObject(SapCloudForCustomerResourceDataset.class);
- Assertions.assertEquals("whrjkejvaedogzo", model.description());
- Assertions.assertEquals("ywusrjzhdtr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ybsz").type());
- Assertions.assertEquals("ovqmqcudptoqwr", model.folder().name());
+ Assertions.assertEquals("keknumkqafzv", model.description());
+ Assertions.assertEquals("kdvvoydwedggwg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("rqw").type());
+ Assertions.assertEquals("j", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTypePropertiesTests.java
index 83fe466a73a4..e1661ced5b69 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerResourceDatasetTypePropertiesTests.java
@@ -10,15 +10,14 @@
public final class SapCloudForCustomerResourceDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SapCloudForCustomerResourceDatasetTypeProperties model
- = BinaryData.fromString("{\"path\":\"datakngejjxumowy\"}")
- .toObject(SapCloudForCustomerResourceDatasetTypeProperties.class);
+ SapCloudForCustomerResourceDatasetTypeProperties model = BinaryData.fromString("{\"path\":\"dataygotoh\"}")
+ .toObject(SapCloudForCustomerResourceDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SapCloudForCustomerResourceDatasetTypeProperties model
- = new SapCloudForCustomerResourceDatasetTypeProperties().withPath("datakngejjxumowy");
+ = new SapCloudForCustomerResourceDatasetTypeProperties().withPath("dataygotoh");
model = BinaryData.fromObject(model).toObject(SapCloudForCustomerResourceDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSinkTests.java
index 8a9b1082ad1b..e346865a2064 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSinkTests.java
@@ -13,22 +13,22 @@ public final class SapCloudForCustomerSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapCloudForCustomerSink model = BinaryData.fromString(
- "{\"type\":\"SapCloudForCustomerSink\",\"writeBehavior\":\"Update\",\"httpRequestTimeout\":\"datagwmu\",\"writeBatchSize\":\"datachvqwhscvaqdxgel\",\"writeBatchTimeout\":\"datagftqkgavgoul\",\"sinkRetryCount\":\"datapaylk\",\"sinkRetryWait\":\"datastbkskkziebmwyo\",\"maxConcurrentConnections\":\"datamplgdxdtxbrdbw\",\"disableMetricsCollection\":\"datatxpfofr\",\"\":{\"ukqscmd\":\"databbnoevkkrlkd\"}}")
+ "{\"type\":\"SapCloudForCustomerSink\",\"writeBehavior\":\"Insert\",\"httpRequestTimeout\":\"datavvufqukjuosajqn\",\"writeBatchSize\":\"datacqdthmlqamdlcu\",\"writeBatchTimeout\":\"datamrvryakc\",\"sinkRetryCount\":\"datasnprda\",\"sinkRetryWait\":\"dataqgabbxexacgmt\",\"maxConcurrentConnections\":\"dataxb\",\"disableMetricsCollection\":\"databovexsnmww\",\"\":{\"kdl\":\"dataujlsztpygq\",\"mkc\":\"datasn\",\"n\":\"datamksfejzmyvlbz\",\"ovhddvtnbtvl\":\"dataxzpdnb\"}}")
.toObject(SapCloudForCustomerSink.class);
- Assertions.assertEquals(SapCloudForCustomerSinkWriteBehavior.UPDATE, model.writeBehavior());
+ Assertions.assertEquals(SapCloudForCustomerSinkWriteBehavior.INSERT, model.writeBehavior());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapCloudForCustomerSink model = new SapCloudForCustomerSink().withWriteBatchSize("datachvqwhscvaqdxgel")
- .withWriteBatchTimeout("datagftqkgavgoul")
- .withSinkRetryCount("datapaylk")
- .withSinkRetryWait("datastbkskkziebmwyo")
- .withMaxConcurrentConnections("datamplgdxdtxbrdbw")
- .withDisableMetricsCollection("datatxpfofr")
- .withWriteBehavior(SapCloudForCustomerSinkWriteBehavior.UPDATE)
- .withHttpRequestTimeout("datagwmu");
+ SapCloudForCustomerSink model = new SapCloudForCustomerSink().withWriteBatchSize("datacqdthmlqamdlcu")
+ .withWriteBatchTimeout("datamrvryakc")
+ .withSinkRetryCount("datasnprda")
+ .withSinkRetryWait("dataqgabbxexacgmt")
+ .withMaxConcurrentConnections("dataxb")
+ .withDisableMetricsCollection("databovexsnmww")
+ .withWriteBehavior(SapCloudForCustomerSinkWriteBehavior.INSERT)
+ .withHttpRequestTimeout("datavvufqukjuosajqn");
model = BinaryData.fromObject(model).toObject(SapCloudForCustomerSink.class);
- Assertions.assertEquals(SapCloudForCustomerSinkWriteBehavior.UPDATE, model.writeBehavior());
+ Assertions.assertEquals(SapCloudForCustomerSinkWriteBehavior.INSERT, model.writeBehavior());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSourceTests.java
index 1c164439ed00..d3d798c443ac 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapCloudForCustomerSourceTests.java
@@ -11,20 +11,20 @@ public final class SapCloudForCustomerSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapCloudForCustomerSource model = BinaryData.fromString(
- "{\"type\":\"SapCloudForCustomerSource\",\"query\":\"datacnk\",\"httpRequestTimeout\":\"datamiecfmqc\",\"queryTimeout\":\"datapcdbvcxo\",\"additionalColumns\":\"datahefuhnbdl\",\"sourceRetryCount\":\"datawectz\",\"sourceRetryWait\":\"datagvcbt\",\"maxConcurrentConnections\":\"datampnkyvujhej\",\"disableMetricsCollection\":\"datarvlguy\",\"\":{\"kormrcjshtcfn\":\"datangnbqhmuqyz\",\"ehuboq\":\"dataffdaxlyhxpdq\",\"glynbqpeo\":\"datazxnuxamxikhrxi\",\"wtihtnywgtsodnx\":\"dataecbog\"}}")
+ "{\"type\":\"SapCloudForCustomerSource\",\"query\":\"datauztb\",\"httpRequestTimeout\":\"datatfmcnrgwgcsto\",\"queryTimeout\":\"dataveehmvr\",\"additionalColumns\":\"dataurpzry\",\"sourceRetryCount\":\"datafdhch\",\"sourceRetryWait\":\"datawahaxyrdlvb\",\"maxConcurrentConnections\":\"datahfqsjzlckt\",\"disableMetricsCollection\":\"datagxteehyhxgnlpj\",\"\":{\"mijhnjk\":\"dataez\",\"huwz\":\"dataco\",\"bhobdocfv\":\"datankzbdeyhw\",\"jfzxsazu\":\"datajmmdmbylyndtq\"}}")
.toObject(SapCloudForCustomerSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapCloudForCustomerSource model = new SapCloudForCustomerSource().withSourceRetryCount("datawectz")
- .withSourceRetryWait("datagvcbt")
- .withMaxConcurrentConnections("datampnkyvujhej")
- .withDisableMetricsCollection("datarvlguy")
- .withQueryTimeout("datapcdbvcxo")
- .withAdditionalColumns("datahefuhnbdl")
- .withQuery("datacnk")
- .withHttpRequestTimeout("datamiecfmqc");
+ SapCloudForCustomerSource model = new SapCloudForCustomerSource().withSourceRetryCount("datafdhch")
+ .withSourceRetryWait("datawahaxyrdlvb")
+ .withMaxConcurrentConnections("datahfqsjzlckt")
+ .withDisableMetricsCollection("datagxteehyhxgnlpj")
+ .withQueryTimeout("dataveehmvr")
+ .withAdditionalColumns("dataurpzry")
+ .withQuery("datauztb")
+ .withHttpRequestTimeout("datatfmcnrgwgcsto");
model = BinaryData.fromObject(model).toObject(SapCloudForCustomerSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTests.java
index 516a140e945e..29eb5bb6953f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTests.java
@@ -19,32 +19,35 @@ public final class SapEccResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapEccResourceDataset model = BinaryData.fromString(
- "{\"type\":\"SapEccResource\",\"typeProperties\":{\"path\":\"datajmoozmxuk\"},\"description\":\"rs\",\"structure\":\"datamnkxjou\",\"schema\":\"datazcfdtstiaxtyrnu\",\"linkedServiceName\":{\"referenceName\":\"cfhep\",\"parameters\":{\"q\":\"databcmlroiommems\",\"abebckc\":\"datablcyeqdobobaq\",\"pjcxbjgfm\":\"datasrsixwn\"}},\"parameters\":{\"y\":{\"type\":\"Float\",\"defaultValue\":\"datarridzfps\"}},\"annotations\":[\"datadfhmlx\",\"dataq\",\"dataekn\",\"datamkqafzvptriy\"],\"folder\":{\"name\":\"gt\"},\"\":{\"dwedg\":\"datapuqpsrcekdvvo\",\"clvbwatza\":\"dataw\"}}")
+ "{\"type\":\"SapEccResource\",\"typeProperties\":{\"path\":\"datawtoi\"},\"description\":\"bxitrapwzhlutj\",\"structure\":\"datazelsr\",\"schema\":\"datamvupm\",\"linkedServiceName\":{\"referenceName\":\"akosysycvldee\",\"parameters\":{\"egbvbbd\":\"datasaipusuof\",\"f\":\"dataedfflzvsluazz\",\"ee\":\"dataveugpx\",\"scboxra\":\"datapup\"}},\"parameters\":{\"fdr\":{\"type\":\"Float\",\"defaultValue\":\"datarjgobekxeheowsec\"},\"seesacuicnvq\":{\"type\":\"Int\",\"defaultValue\":\"dataskiwrjsbdb\"},\"vmrfaptndrmmn\":{\"type\":\"Array\",\"defaultValue\":\"datau\"}},\"annotations\":[\"datak\",\"dataxrqkekcdavi\",\"dataebeqrfza\",\"dataqymcwt\"],\"folder\":{\"name\":\"ceplbrzgkuorwpq\"},\"\":{\"ykk\":\"dataweobptscr\",\"sbnlyoifgdfzjqth\":\"dataelayynoyjyfls\",\"kxxlwwo\":\"datakcvoevcwfzo\",\"ubdmg\":\"dataxgbsdzcgcvypj\"}}")
.toObject(SapEccResourceDataset.class);
- Assertions.assertEquals("rs", model.description());
- Assertions.assertEquals("cfhep", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("y").type());
- Assertions.assertEquals("gt", model.folder().name());
+ Assertions.assertEquals("bxitrapwzhlutj", model.description());
+ Assertions.assertEquals("akosysycvldee", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("fdr").type());
+ Assertions.assertEquals("ceplbrzgkuorwpq", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapEccResourceDataset model = new SapEccResourceDataset().withDescription("rs")
- .withStructure("datamnkxjou")
- .withSchema("datazcfdtstiaxtyrnu")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("cfhep")
- .withParameters(
- mapOf("q", "databcmlroiommems", "abebckc", "datablcyeqdobobaq", "pjcxbjgfm", "datasrsixwn")))
- .withParameters(
- mapOf("y", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datarridzfps")))
- .withAnnotations(Arrays.asList("datadfhmlx", "dataq", "dataekn", "datamkqafzvptriy"))
- .withFolder(new DatasetFolder().withName("gt"))
- .withPath("datajmoozmxuk");
+ SapEccResourceDataset model = new SapEccResourceDataset().withDescription("bxitrapwzhlutj")
+ .withStructure("datazelsr")
+ .withSchema("datamvupm")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("akosysycvldee")
+ .withParameters(mapOf("egbvbbd", "datasaipusuof", "f", "dataedfflzvsluazz", "ee", "dataveugpx",
+ "scboxra", "datapup")))
+ .withParameters(mapOf("fdr",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datarjgobekxeheowsec"),
+ "seesacuicnvq",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataskiwrjsbdb"),
+ "vmrfaptndrmmn", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datau")))
+ .withAnnotations(Arrays.asList("datak", "dataxrqkekcdavi", "dataebeqrfza", "dataqymcwt"))
+ .withFolder(new DatasetFolder().withName("ceplbrzgkuorwpq"))
+ .withPath("datawtoi");
model = BinaryData.fromObject(model).toObject(SapEccResourceDataset.class);
- Assertions.assertEquals("rs", model.description());
- Assertions.assertEquals("cfhep", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("y").type());
- Assertions.assertEquals("gt", model.folder().name());
+ Assertions.assertEquals("bxitrapwzhlutj", model.description());
+ Assertions.assertEquals("akosysycvldee", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("fdr").type());
+ Assertions.assertEquals("ceplbrzgkuorwpq", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTypePropertiesTests.java
index 515da95dd354..414df87ef63b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccResourceDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class SapEccResourceDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SapEccResourceDatasetTypeProperties model = BinaryData.fromString("{\"path\":\"datarjbjngoarsr\"}")
+ SapEccResourceDatasetTypeProperties model = BinaryData.fromString("{\"path\":\"databxehujcqgzwvx\"}")
.toObject(SapEccResourceDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SapEccResourceDatasetTypeProperties model
- = new SapEccResourceDatasetTypeProperties().withPath("datarjbjngoarsr");
+ = new SapEccResourceDatasetTypeProperties().withPath("databxehujcqgzwvx");
model = BinaryData.fromObject(model).toObject(SapEccResourceDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccSourceTests.java
index 6495341e696b..37a7516e9212 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapEccSourceTests.java
@@ -11,20 +11,20 @@ public final class SapEccSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapEccSource model = BinaryData.fromString(
- "{\"type\":\"SapEccSource\",\"query\":\"datarjtwjimcfrhtz\",\"httpRequestTimeout\":\"datauvoaxqo\",\"queryTimeout\":\"datalp\",\"additionalColumns\":\"datapbzyqbggxcyra\",\"sourceRetryCount\":\"datazuaxtbr\",\"sourceRetryWait\":\"datayurxlpuwxslzq\",\"maxConcurrentConnections\":\"datax\",\"disableMetricsCollection\":\"datanrurtnwbjj\",\"\":{\"lshma\":\"datapckhfbmdemo\",\"fltbsayvmwa\":\"datao\",\"kqcm\":\"datajx\",\"tn\":\"datadc\"}}")
+ "{\"type\":\"SapEccSource\",\"query\":\"datahwwtlerhpfrarq\",\"httpRequestTimeout\":\"dataushs\",\"queryTimeout\":\"datatvnqcmrr\",\"additionalColumns\":\"datalwgomhscs\",\"sourceRetryCount\":\"datalcnwbijxfcngef\",\"sourceRetryWait\":\"datag\",\"maxConcurrentConnections\":\"datadmrowhrrguvd\",\"disableMetricsCollection\":\"datagucwawlmsikl\",\"\":{\"mijzhrbsxjvu\":\"datadfcphg\"}}")
.toObject(SapEccSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapEccSource model = new SapEccSource().withSourceRetryCount("datazuaxtbr")
- .withSourceRetryWait("datayurxlpuwxslzq")
- .withMaxConcurrentConnections("datax")
- .withDisableMetricsCollection("datanrurtnwbjj")
- .withQueryTimeout("datalp")
- .withAdditionalColumns("datapbzyqbggxcyra")
- .withQuery("datarjtwjimcfrhtz")
- .withHttpRequestTimeout("datauvoaxqo");
+ SapEccSource model = new SapEccSource().withSourceRetryCount("datalcnwbijxfcngef")
+ .withSourceRetryWait("datag")
+ .withMaxConcurrentConnections("datadmrowhrrguvd")
+ .withDisableMetricsCollection("datagucwawlmsikl")
+ .withQueryTimeout("datatvnqcmrr")
+ .withAdditionalColumns("datalwgomhscs")
+ .withQuery("datahwwtlerhpfrarq")
+ .withHttpRequestTimeout("dataushs");
model = BinaryData.fromObject(model).toObject(SapEccSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaPartitionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaPartitionSettingsTests.java
index 965e588d18ae..2ebdc604e812 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaPartitionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaPartitionSettingsTests.java
@@ -10,13 +10,13 @@
public final class SapHanaPartitionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SapHanaPartitionSettings model = BinaryData.fromString("{\"partitionColumnName\":\"datazvixty\"}")
+ SapHanaPartitionSettings model = BinaryData.fromString("{\"partitionColumnName\":\"datapadkts\"}")
.toObject(SapHanaPartitionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapHanaPartitionSettings model = new SapHanaPartitionSettings().withPartitionColumnName("datazvixty");
+ SapHanaPartitionSettings model = new SapHanaPartitionSettings().withPartitionColumnName("datapadkts");
model = BinaryData.fromObject(model).toObject(SapHanaPartitionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaSourceTests.java
index 3b7bc1b39639..9ec97976a8a2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaSourceTests.java
@@ -12,22 +12,22 @@ public final class SapHanaSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapHanaSource model = BinaryData.fromString(
- "{\"type\":\"SapHanaSource\",\"query\":\"datartqegab\",\"packetSize\":\"datajrjz\",\"partitionOption\":\"datascgorv\",\"partitionSettings\":{\"partitionColumnName\":\"databepgfrbijoeh\"},\"queryTimeout\":\"datawwsgqziwo\",\"additionalColumns\":\"datatwjssyazmmbu\",\"sourceRetryCount\":\"datato\",\"sourceRetryWait\":\"datakxfkftqkbyru\",\"maxConcurrentConnections\":\"dataawucmqfurbtbo\",\"disableMetricsCollection\":\"datalyve\",\"\":{\"ijwiznb\":\"datajguwts\"}}")
+ "{\"type\":\"SapHanaSource\",\"query\":\"dataouelfyqf\",\"packetSize\":\"dataeblpdwckmnpzubzq\",\"partitionOption\":\"datawgfjrgngcpbsh\",\"partitionSettings\":{\"partitionColumnName\":\"datalcfem\"},\"queryTimeout\":\"datayxnklfswz\",\"additionalColumns\":\"dataigxsyxhygczab\",\"sourceRetryCount\":\"dataeu\",\"sourceRetryWait\":\"datazf\",\"maxConcurrentConnections\":\"datauop\",\"disableMetricsCollection\":\"dataiaos\",\"\":{\"qgllnhgisiw\":\"datautgkmrsq\",\"aefw\":\"datazkaeqrnglgit\"}}")
.toObject(SapHanaSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapHanaSource model = new SapHanaSource().withSourceRetryCount("datato")
- .withSourceRetryWait("datakxfkftqkbyru")
- .withMaxConcurrentConnections("dataawucmqfurbtbo")
- .withDisableMetricsCollection("datalyve")
- .withQueryTimeout("datawwsgqziwo")
- .withAdditionalColumns("datatwjssyazmmbu")
- .withQuery("datartqegab")
- .withPacketSize("datajrjz")
- .withPartitionOption("datascgorv")
- .withPartitionSettings(new SapHanaPartitionSettings().withPartitionColumnName("databepgfrbijoeh"));
+ SapHanaSource model = new SapHanaSource().withSourceRetryCount("dataeu")
+ .withSourceRetryWait("datazf")
+ .withMaxConcurrentConnections("datauop")
+ .withDisableMetricsCollection("dataiaos")
+ .withQueryTimeout("datayxnklfswz")
+ .withAdditionalColumns("dataigxsyxhygczab")
+ .withQuery("dataouelfyqf")
+ .withPacketSize("dataeblpdwckmnpzubzq")
+ .withPartitionOption("datawgfjrgngcpbsh")
+ .withPartitionSettings(new SapHanaPartitionSettings().withPartitionColumnName("datalcfem"));
model = BinaryData.fromObject(model).toObject(SapHanaSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTests.java
index 848be205b2c2..7f34ead98907 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTests.java
@@ -19,34 +19,37 @@ public final class SapHanaTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapHanaTableDataset model = BinaryData.fromString(
- "{\"type\":\"SapHanaTable\",\"typeProperties\":{\"schema\":\"datai\",\"table\":\"datazcyniapy\"},\"description\":\"mrxirqwipzesstu\",\"structure\":\"dataytkmlfupj\",\"schema\":\"datax\",\"linkedServiceName\":{\"referenceName\":\"vzjoyxjgahxue\",\"parameters\":{\"erfcv\":\"dataaktnytkb\",\"hnhhcikh\":\"datapvfqjckmpwyv\",\"lsac\":\"dataebgjg\",\"ygotoh\":\"datagiflr\"}},\"parameters\":{\"tjsjzelsriemvu\":{\"type\":\"String\",\"defaultValue\":\"datadhbxitrapwzhl\"},\"cb\":{\"type\":\"Int\",\"defaultValue\":\"dataakosysycvldee\"}},\"annotations\":[\"datapus\",\"dataofkegbvbbdledffl\",\"datavsluazzxfjv\",\"dataugpxzeempup\"],\"folder\":{\"name\":\"boxraqdczmr\"},\"\":{\"drzzbskiwrjsb\":\"databekxeheowseca\",\"qsuivmrfaptndrmm\":\"databmseesacuicnvq\"}}")
+ "{\"type\":\"SapHanaTable\",\"typeProperties\":{\"schema\":\"dataaoibmjk\",\"table\":\"datarljd\"},\"description\":\"kylaxrjiqoqovqhg\",\"structure\":\"datagxuwudgcyqru\",\"schema\":\"datamryddnqivahfcq\",\"linkedServiceName\":{\"referenceName\":\"njze\",\"parameters\":{\"w\":\"datacciyoypoedks\",\"xuyxsxteuikhzn\":\"dataibpybqei\",\"rkrgsdc\":\"dataffnhcgnaqsrmrfqd\"}},\"parameters\":{\"byzposzfutgpbygb\":{\"type\":\"Array\",\"defaultValue\":\"dataqlwyqzn\"},\"zpvqewflwzhxzuxe\":{\"type\":\"SecureString\",\"defaultValue\":\"datamoiqg\"},\"ajdqxymxx\":{\"type\":\"Float\",\"defaultValue\":\"dataywlrkqsqvvdkfpfj\"}},\"annotations\":[\"datadjidcetfvgwfws\",\"datadigwoup\"],\"folder\":{\"name\":\"ddqsvclrsnxfrp\"},\"\":{\"tfxxepzpxzxlcqz\":\"dataqclmd\",\"jbsmkirpqni\":\"dataxaitiqm\",\"uzltenlb\":\"dataudmhkcomeobwk\",\"uomtxj\":\"dataxlmxozesndo\"}}")
.toObject(SapHanaTableDataset.class);
- Assertions.assertEquals("mrxirqwipzesstu", model.description());
- Assertions.assertEquals("vzjoyxjgahxue", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("tjsjzelsriemvu").type());
- Assertions.assertEquals("boxraqdczmr", model.folder().name());
+ Assertions.assertEquals("kylaxrjiqoqovqhg", model.description());
+ Assertions.assertEquals("njze", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("byzposzfutgpbygb").type());
+ Assertions.assertEquals("ddqsvclrsnxfrp", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapHanaTableDataset model = new SapHanaTableDataset().withDescription("mrxirqwipzesstu")
- .withStructure("dataytkmlfupj")
- .withSchema("datax")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vzjoyxjgahxue")
- .withParameters(mapOf("erfcv", "dataaktnytkb", "hnhhcikh", "datapvfqjckmpwyv", "lsac", "dataebgjg",
- "ygotoh", "datagiflr")))
- .withParameters(mapOf("tjsjzelsriemvu",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("datadhbxitrapwzhl"), "cb",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataakosysycvldee")))
- .withAnnotations(Arrays.asList("datapus", "dataofkegbvbbdledffl", "datavsluazzxfjv", "dataugpxzeempup"))
- .withFolder(new DatasetFolder().withName("boxraqdczmr"))
- .withSchemaTypePropertiesSchema("datai")
- .withTable("datazcyniapy");
+ SapHanaTableDataset model = new SapHanaTableDataset().withDescription("kylaxrjiqoqovqhg")
+ .withStructure("datagxuwudgcyqru")
+ .withSchema("datamryddnqivahfcq")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("njze")
+ .withParameters(mapOf("w", "datacciyoypoedks", "xuyxsxteuikhzn", "dataibpybqei", "rkrgsdc",
+ "dataffnhcgnaqsrmrfqd")))
+ .withParameters(mapOf("byzposzfutgpbygb",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataqlwyqzn"),
+ "zpvqewflwzhxzuxe",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datamoiqg"),
+ "ajdqxymxx",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataywlrkqsqvvdkfpfj")))
+ .withAnnotations(Arrays.asList("datadjidcetfvgwfws", "datadigwoup"))
+ .withFolder(new DatasetFolder().withName("ddqsvclrsnxfrp"))
+ .withSchemaTypePropertiesSchema("dataaoibmjk")
+ .withTable("datarljd");
model = BinaryData.fromObject(model).toObject(SapHanaTableDataset.class);
- Assertions.assertEquals("mrxirqwipzesstu", model.description());
- Assertions.assertEquals("vzjoyxjgahxue", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("tjsjzelsriemvu").type());
- Assertions.assertEquals("boxraqdczmr", model.folder().name());
+ Assertions.assertEquals("kylaxrjiqoqovqhg", model.description());
+ Assertions.assertEquals("njze", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("byzposzfutgpbygb").type());
+ Assertions.assertEquals("ddqsvclrsnxfrp", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTypePropertiesTests.java
index bd949f9968c0..c974699733ff 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapHanaTableDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class SapHanaTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapHanaTableDatasetTypeProperties model
- = BinaryData.fromString("{\"schema\":\"datahnkmxrqkek\",\"table\":\"dataaviiebeqrfz\"}")
+ = BinaryData.fromString("{\"schema\":\"dataixymckik\",\"table\":\"datayvurhwishy\"}")
.toObject(SapHanaTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SapHanaTableDatasetTypeProperties model
- = new SapHanaTableDatasetTypeProperties().withSchema("datahnkmxrqkek").withTable("dataaviiebeqrfz");
+ = new SapHanaTableDatasetTypeProperties().withSchema("dataixymckik").withTable("datayvurhwishy");
model = BinaryData.fromObject(model).toObject(SapHanaTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTests.java
index 905feb9d4e31..058ac193f1c6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTests.java
@@ -19,35 +19,36 @@ public final class SapOdpResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapOdpResourceDataset model = BinaryData.fromString(
- "{\"type\":\"SapOdpResource\",\"typeProperties\":{\"context\":\"datawuuqbmenxcqsxwc\",\"objectName\":\"dataykc\"},\"description\":\"dek\",\"structure\":\"datanjre\",\"schema\":\"dataptedeuenthshnfi\",\"linkedServiceName\":{\"referenceName\":\"gpgpkkhpjnglaqlm\",\"parameters\":{\"ecpvfpnrzikvo\":\"datamtrdlpxiww\",\"ivxdifbwblijhp\":\"dataloeohy\"}},\"parameters\":{\"xr\":{\"type\":\"SecureString\",\"defaultValue\":\"dataoyxontbwdq\"},\"fewxatktwjrppi\":{\"type\":\"String\",\"defaultValue\":\"dataqrrldxfua\"},\"jklwjp\":{\"type\":\"Array\",\"defaultValue\":\"datarqvelrmdcizhvksb\"}},\"annotations\":[\"datancw\",\"datasmpyeyzolbfnfly\"],\"folder\":{\"name\":\"uduiqoom\"},\"\":{\"liyznghuqzgp\":\"datakqwopws\",\"fy\":\"dataglkfvdwrgav\"}}")
+ "{\"type\":\"SapOdpResource\",\"typeProperties\":{\"context\":\"datauzimbwttmhlvr\",\"objectName\":\"datacyxrn\"},\"description\":\"kfajnpdwzjggkw\",\"structure\":\"datap\",\"schema\":\"dataziayfiqiidxcor\",\"linkedServiceName\":{\"referenceName\":\"vudyhgtrttcuayi\",\"parameters\":{\"zifb\":\"datankmm\",\"rtgqrqkk\":\"datagqexowq\",\"kuobpw\":\"datafy\",\"pnyjtu\":\"datainpgobothxiew\"}},\"parameters\":{\"uwh\":{\"type\":\"Object\",\"defaultValue\":\"dataextchslroldo\"},\"gkudsozodwjc\":{\"type\":\"Bool\",\"defaultValue\":\"dataifiozttcbiic\"},\"mz\":{\"type\":\"Float\",\"defaultValue\":\"datayxryqyc\"}},\"annotations\":[\"datafgdwzauz\",\"datadheadnyciwz\",\"datailykqadfgesv\"],\"folder\":{\"name\":\"a\"},\"\":{\"ovqmxqsxofx\":\"dataizmadjrsbgailj\",\"kgltsxooiobhieb\":\"datankiu\",\"tlsrvqzgaqsosrn\":\"datau\",\"npesw\":\"datalvgrghnhuoxrqhjn\"}}")
.toObject(SapOdpResourceDataset.class);
- Assertions.assertEquals("dek", model.description());
- Assertions.assertEquals("gpgpkkhpjnglaqlm", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("xr").type());
- Assertions.assertEquals("uduiqoom", model.folder().name());
+ Assertions.assertEquals("kfajnpdwzjggkw", model.description());
+ Assertions.assertEquals("vudyhgtrttcuayi", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("uwh").type());
+ Assertions.assertEquals("a", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapOdpResourceDataset model = new SapOdpResourceDataset().withDescription("dek")
- .withStructure("datanjre")
- .withSchema("dataptedeuenthshnfi")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("gpgpkkhpjnglaqlm")
- .withParameters(mapOf("ecpvfpnrzikvo", "datamtrdlpxiww", "ivxdifbwblijhp", "dataloeohy")))
- .withParameters(mapOf("xr",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataoyxontbwdq"),
- "fewxatktwjrppi",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataqrrldxfua"), "jklwjp",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datarqvelrmdcizhvksb")))
- .withAnnotations(Arrays.asList("datancw", "datasmpyeyzolbfnfly"))
- .withFolder(new DatasetFolder().withName("uduiqoom"))
- .withContext("datawuuqbmenxcqsxwc")
- .withObjectName("dataykc");
+ SapOdpResourceDataset model = new SapOdpResourceDataset().withDescription("kfajnpdwzjggkw")
+ .withStructure("datap")
+ .withSchema("dataziayfiqiidxcor")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vudyhgtrttcuayi")
+ .withParameters(mapOf("zifb", "datankmm", "rtgqrqkk", "datagqexowq", "kuobpw", "datafy", "pnyjtu",
+ "datainpgobothxiew")))
+ .withParameters(mapOf("uwh",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataextchslroldo"),
+ "gkudsozodwjc",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataifiozttcbiic"), "mz",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datayxryqyc")))
+ .withAnnotations(Arrays.asList("datafgdwzauz", "datadheadnyciwz", "datailykqadfgesv"))
+ .withFolder(new DatasetFolder().withName("a"))
+ .withContext("datauzimbwttmhlvr")
+ .withObjectName("datacyxrn");
model = BinaryData.fromObject(model).toObject(SapOdpResourceDataset.class);
- Assertions.assertEquals("dek", model.description());
- Assertions.assertEquals("gpgpkkhpjnglaqlm", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("xr").type());
- Assertions.assertEquals("uduiqoom", model.folder().name());
+ Assertions.assertEquals("kfajnpdwzjggkw", model.description());
+ Assertions.assertEquals("vudyhgtrttcuayi", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("uwh").type());
+ Assertions.assertEquals("a", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTypePropertiesTests.java
index 1bb78d4859ca..88f69ca6009d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpResourceDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class SapOdpResourceDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapOdpResourceDatasetTypeProperties model
- = BinaryData.fromString("{\"context\":\"datasedfmzu\",\"objectName\":\"dataryxpi\"}")
+ = BinaryData.fromString("{\"context\":\"datanhqkgebzqz\",\"objectName\":\"datacsviu\"}")
.toObject(SapOdpResourceDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SapOdpResourceDatasetTypeProperties model
- = new SapOdpResourceDatasetTypeProperties().withContext("datasedfmzu").withObjectName("dataryxpi");
+ = new SapOdpResourceDatasetTypeProperties().withContext("datanhqkgebzqz").withObjectName("datacsviu");
model = BinaryData.fromObject(model).toObject(SapOdpResourceDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpSourceTests.java
index 1b846e05d175..bb86ffc99d91 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOdpSourceTests.java
@@ -11,22 +11,22 @@ public final class SapOdpSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapOdpSource model = BinaryData.fromString(
- "{\"type\":\"SapOdpSource\",\"extractionMode\":\"dataiumuzt\",\"subscriberProcess\":\"datajtfmcnrgwgcstozr\",\"selection\":\"dataehmvrveurpzrysef\",\"projection\":\"datachkkwah\",\"queryTimeout\":\"datayrdlvbomhfqsjz\",\"additionalColumns\":\"dataktk\",\"sourceRetryCount\":\"dataxtee\",\"sourceRetryWait\":\"datahxgnlpjytle\",\"maxConcurrentConnections\":\"datamijhnjk\",\"disableMetricsCollection\":\"dataohhuw\",\"\":{\"b\":\"datakzbdeyhwebh\",\"lynd\":\"dataocfvajmmdmb\",\"fzxs\":\"dataqu\"}}")
+ "{\"type\":\"SapOdpSource\",\"extractionMode\":\"dataimvlocdxvhkob\",\"subscriberProcess\":\"datahhipn\",\"selection\":\"datadd\",\"projection\":\"dataiwanvydgmqscijlf\",\"queryTimeout\":\"dataxgnzasvpm\",\"additionalColumns\":\"dataooqyp\",\"sourceRetryCount\":\"datalm\",\"sourceRetryWait\":\"dataebv\",\"maxConcurrentConnections\":\"datahoydehbvbex\",\"disableMetricsCollection\":\"dataynnladdhdklwzz\",\"\":{\"sacrnpscfke\":\"databb\",\"uvjvtgecehennle\":\"dataeltxefamimg\"}}")
.toObject(SapOdpSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapOdpSource model = new SapOdpSource().withSourceRetryCount("dataxtee")
- .withSourceRetryWait("datahxgnlpjytle")
- .withMaxConcurrentConnections("datamijhnjk")
- .withDisableMetricsCollection("dataohhuw")
- .withQueryTimeout("datayrdlvbomhfqsjz")
- .withAdditionalColumns("dataktk")
- .withExtractionMode("dataiumuzt")
- .withSubscriberProcess("datajtfmcnrgwgcstozr")
- .withSelection("dataehmvrveurpzrysef")
- .withProjection("datachkkwah");
+ SapOdpSource model = new SapOdpSource().withSourceRetryCount("datalm")
+ .withSourceRetryWait("dataebv")
+ .withMaxConcurrentConnections("datahoydehbvbex")
+ .withDisableMetricsCollection("dataynnladdhdklwzz")
+ .withQueryTimeout("dataxgnzasvpm")
+ .withAdditionalColumns("dataooqyp")
+ .withExtractionMode("dataimvlocdxvhkob")
+ .withSubscriberProcess("datahhipn")
+ .withSelection("datadd")
+ .withProjection("dataiwanvydgmqscijlf");
model = BinaryData.fromObject(model).toObject(SapOdpSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubSourceTests.java
index 14bbb66fb836..645aa8dea1b0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubSourceTests.java
@@ -11,22 +11,22 @@ public final class SapOpenHubSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapOpenHubSource model = BinaryData.fromString(
- "{\"type\":\"SapOpenHubSource\",\"excludeLastRequest\":\"datar\",\"baseRequestId\":\"datalximvr\",\"customRfcReadTableFunctionModule\":\"datajja\",\"sapDataColumnDelimiter\":\"dataaskullvtsauj\",\"queryTimeout\":\"datahtz\",\"additionalColumns\":\"datazqrpfhzxkjyg\",\"sourceRetryCount\":\"dataidgwdhawj\",\"sourceRetryWait\":\"datazb\",\"maxConcurrentConnections\":\"datat\",\"disableMetricsCollection\":\"datacmxqdexnkp\",\"\":{\"kpn\":\"datacmsmz\"}}")
+ "{\"type\":\"SapOpenHubSource\",\"excludeLastRequest\":\"datawaojrfq\",\"baseRequestId\":\"datakkiupmd\",\"customRfcReadTableFunctionModule\":\"dataqp\",\"sapDataColumnDelimiter\":\"datavzbejx\",\"queryTimeout\":\"datakiff\",\"additionalColumns\":\"datawdyzse\",\"sourceRetryCount\":\"datamvtqhn\",\"sourceRetryWait\":\"dataiju\",\"maxConcurrentConnections\":\"datarkqywybxgayomse\",\"disableMetricsCollection\":\"datacxl\",\"\":{\"loe\":\"dataqfblsizxpolpsa\"}}")
.toObject(SapOpenHubSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapOpenHubSource model = new SapOpenHubSource().withSourceRetryCount("dataidgwdhawj")
- .withSourceRetryWait("datazb")
- .withMaxConcurrentConnections("datat")
- .withDisableMetricsCollection("datacmxqdexnkp")
- .withQueryTimeout("datahtz")
- .withAdditionalColumns("datazqrpfhzxkjyg")
- .withExcludeLastRequest("datar")
- .withBaseRequestId("datalximvr")
- .withCustomRfcReadTableFunctionModule("datajja")
- .withSapDataColumnDelimiter("dataaskullvtsauj");
+ SapOpenHubSource model = new SapOpenHubSource().withSourceRetryCount("datamvtqhn")
+ .withSourceRetryWait("dataiju")
+ .withMaxConcurrentConnections("datarkqywybxgayomse")
+ .withDisableMetricsCollection("datacxl")
+ .withQueryTimeout("datakiff")
+ .withAdditionalColumns("datawdyzse")
+ .withExcludeLastRequest("datawaojrfq")
+ .withBaseRequestId("datakkiupmd")
+ .withCustomRfcReadTableFunctionModule("dataqp")
+ .withSapDataColumnDelimiter("datavzbejx");
model = BinaryData.fromObject(model).toObject(SapOpenHubSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTests.java
index 5cd3acc80ea4..36526dcd0a18 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTests.java
@@ -19,35 +19,38 @@ public final class SapOpenHubTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapOpenHubTableDataset model = BinaryData.fromString(
- "{\"type\":\"SapOpenHubTable\",\"typeProperties\":{\"openHubDestinationName\":\"datavqymcwtsi\",\"excludeLastRequest\":\"dataeplbrzgkuorwpqbs\",\"baseRequestId\":\"datae\"},\"description\":\"ptscru\",\"structure\":\"dataki\",\"schema\":\"dataayynoyj\",\"linkedServiceName\":{\"referenceName\":\"flsmsbnlyoifg\",\"parameters\":{\"zotkx\":\"datajqthykcvoevcw\",\"cgcvyp\":\"datalwwooxgbsd\",\"jcqgzwvxwi\":\"datahubdmgobxeh\"}},\"parameters\":{\"uky\":{\"type\":\"Int\",\"defaultValue\":\"datamjklqrljd\"}},\"annotations\":[\"datarjiqoqovqhgphgxu\",\"dataud\",\"datacy\"],\"folder\":{\"name\":\"vumryd\"},\"\":{\"iyoypoedkspwwibp\":\"dataivahfcqwnjzebpic\",\"znfffnhcgnaqsrm\":\"databqeigxuyxsxteuik\"}}")
+ "{\"type\":\"SapOpenHubTable\",\"typeProperties\":{\"openHubDestinationName\":\"datamrzcqfevnkyakc\",\"excludeLastRequest\":\"dataehognsddjkkdede\",\"baseRequestId\":\"dataazogfc\"},\"description\":\"cx\",\"structure\":\"dataumtcqxmyvkxixypa\",\"schema\":\"datafjczgohvpsuwi\",\"linkedServiceName\":{\"referenceName\":\"hmxczbyfkocgmzd\",\"parameters\":{\"ngtwgxro\":\"datanlwsc\",\"ihavis\":\"datawvplksdksutacuc\",\"vpmqququxlph\":\"databvjh\"}},\"parameters\":{\"icgym\":{\"type\":\"SecureString\",\"defaultValue\":\"dataexoweorocr\"},\"vhtvijvwmrg\":{\"type\":\"String\",\"defaultValue\":\"dataqpfy\"},\"hbtqyzy\":{\"type\":\"Array\",\"defaultValue\":\"datahrplcxfmbzquuutq\"},\"vxjdqosxzmdz\":{\"type\":\"Int\",\"defaultValue\":\"datambky\"}},\"annotations\":[\"dataqfufkekzfkicxhs\",\"datavmnkgghvsryjok\"],\"folder\":{\"name\":\"vbjsarxsvmfp\"},\"\":{\"hgxg\":\"databpzgfgqpu\",\"ukgsn\":\"dataeabbfpxxavlo\",\"xj\":\"datahw\"}}")
.toObject(SapOpenHubTableDataset.class);
- Assertions.assertEquals("ptscru", model.description());
- Assertions.assertEquals("flsmsbnlyoifg", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("uky").type());
- Assertions.assertEquals("vumryd", model.folder().name());
+ Assertions.assertEquals("cx", model.description());
+ Assertions.assertEquals("hmxczbyfkocgmzd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("icgym").type());
+ Assertions.assertEquals("vbjsarxsvmfp", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapOpenHubTableDataset model
- = new SapOpenHubTableDataset().withDescription("ptscru")
- .withStructure("dataki")
- .withSchema("dataayynoyj")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("flsmsbnlyoifg")
- .withParameters(mapOf("zotkx", "datajqthykcvoevcw", "cgcvyp", "datalwwooxgbsd", "jcqgzwvxwi",
- "datahubdmgobxeh")))
- .withParameters(mapOf("uky",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datamjklqrljd")))
- .withAnnotations(Arrays.asList("datarjiqoqovqhgphgxu", "dataud", "datacy"))
- .withFolder(new DatasetFolder().withName("vumryd"))
- .withOpenHubDestinationName("datavqymcwtsi")
- .withExcludeLastRequest("dataeplbrzgkuorwpqbs")
- .withBaseRequestId("datae");
+ SapOpenHubTableDataset model = new SapOpenHubTableDataset().withDescription("cx")
+ .withStructure("dataumtcqxmyvkxixypa")
+ .withSchema("datafjczgohvpsuwi")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hmxczbyfkocgmzd")
+ .withParameters(
+ mapOf("ngtwgxro", "datanlwsc", "ihavis", "datawvplksdksutacuc", "vpmqququxlph", "databvjh")))
+ .withParameters(mapOf("icgym",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataexoweorocr"),
+ "vhtvijvwmrg", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataqpfy"),
+ "hbtqyzy",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datahrplcxfmbzquuutq"),
+ "vxjdqosxzmdz", new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datambky")))
+ .withAnnotations(Arrays.asList("dataqfufkekzfkicxhs", "datavmnkgghvsryjok"))
+ .withFolder(new DatasetFolder().withName("vbjsarxsvmfp"))
+ .withOpenHubDestinationName("datamrzcqfevnkyakc")
+ .withExcludeLastRequest("dataehognsddjkkdede")
+ .withBaseRequestId("dataazogfc");
model = BinaryData.fromObject(model).toObject(SapOpenHubTableDataset.class);
- Assertions.assertEquals("ptscru", model.description());
- Assertions.assertEquals("flsmsbnlyoifg", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("uky").type());
- Assertions.assertEquals("vumryd", model.folder().name());
+ Assertions.assertEquals("cx", model.description());
+ Assertions.assertEquals("hmxczbyfkocgmzd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("icgym").type());
+ Assertions.assertEquals("vbjsarxsvmfp", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTypePropertiesTests.java
index 46013be81f11..deb57c73f8f8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapOpenHubTableDatasetTypePropertiesTests.java
@@ -11,16 +11,16 @@ public final class SapOpenHubTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapOpenHubTableDatasetTypeProperties model = BinaryData.fromString(
- "{\"openHubDestinationName\":\"datafqderkr\",\"excludeLastRequest\":\"datadcob\",\"baseRequestId\":\"datagqlwyqznbby\"}")
+ "{\"openHubDestinationName\":\"dataf\",\"excludeLastRequest\":\"dataxcebnbeo\",\"baseRequestId\":\"dataemqqerwqx\"}")
.toObject(SapOpenHubTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SapOpenHubTableDatasetTypeProperties model
- = new SapOpenHubTableDatasetTypeProperties().withOpenHubDestinationName("datafqderkr")
- .withExcludeLastRequest("datadcob")
- .withBaseRequestId("datagqlwyqznbby");
+ = new SapOpenHubTableDatasetTypeProperties().withOpenHubDestinationName("dataf")
+ .withExcludeLastRequest("dataxcebnbeo")
+ .withBaseRequestId("dataemqqerwqx");
model = BinaryData.fromObject(model).toObject(SapOpenHubTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTablePartitionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTablePartitionSettingsTests.java
index dee35bb79b3b..401afb72dfa3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTablePartitionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTablePartitionSettingsTests.java
@@ -11,16 +11,16 @@ public final class SapTablePartitionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapTablePartitionSettings model = BinaryData.fromString(
- "{\"partitionColumnName\":\"datakaeqrnglgit\",\"partitionUpperBound\":\"dataefwdkpadktsyy\",\"partitionLowerBound\":\"dataojrfqtfk\",\"maxPartitionsNumber\":\"dataupmdajqpdvvzb\"}")
+ "{\"partitionColumnName\":\"datapnrcrjeypd\",\"partitionUpperBound\":\"datascxzsynbdrqirni\",\"partitionLowerBound\":\"dataothyeb\",\"maxPartitionsNumber\":\"dataesovsvjxnso\"}")
.toObject(SapTablePartitionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapTablePartitionSettings model = new SapTablePartitionSettings().withPartitionColumnName("datakaeqrnglgit")
- .withPartitionUpperBound("dataefwdkpadktsyy")
- .withPartitionLowerBound("dataojrfqtfk")
- .withMaxPartitionsNumber("dataupmdajqpdvvzb");
+ SapTablePartitionSettings model = new SapTablePartitionSettings().withPartitionColumnName("datapnrcrjeypd")
+ .withPartitionUpperBound("datascxzsynbdrqirni")
+ .withPartitionLowerBound("dataothyeb")
+ .withMaxPartitionsNumber("dataesovsvjxnso");
model = BinaryData.fromObject(model).toObject(SapTablePartitionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTests.java
index 1d218bed8e35..74139d5f1378 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTests.java
@@ -19,32 +19,35 @@ public final class SapTableResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapTableResourceDataset model = BinaryData.fromString(
- "{\"type\":\"SapTableResource\",\"typeProperties\":{\"tableName\":\"dataxwjoqfzwand\"},\"description\":\"duwd\",\"structure\":\"datalxtqm\",\"schema\":\"datac\",\"linkedServiceName\":{\"referenceName\":\"s\",\"parameters\":{\"oxedrmrazhvch\":\"databkiumjf\",\"zsoowxcsmxtlcapp\":\"datavoyiogbntnwzr\"}},\"parameters\":{\"pbkmzkwhjjs\":{\"type\":\"Array\",\"defaultValue\":\"dataspciryomhkdwuwed\"},\"vvkxdbnmc\":{\"type\":\"Float\",\"defaultValue\":\"dataaefe\"}},\"annotations\":[\"dataycdzdob\",\"dataesdyvf\"],\"folder\":{\"name\":\"pfdfu\"},\"\":{\"bbkfl\":\"datawpdpsegivytab\"}}")
+ "{\"type\":\"SapTableResource\",\"typeProperties\":{\"tableName\":\"datadngvnqdjgsbtwg\"},\"description\":\"dxuczl\",\"structure\":\"datab\",\"schema\":\"datacznrirpiiuvcqo\",\"linkedServiceName\":{\"referenceName\":\"kqwucqsd\",\"parameters\":{\"kjlamyvwprjmaiht\":\"datacwtvmijccp\",\"ppvolzayjw\":\"datanlbhxjppcbqetfz\"}},\"parameters\":{\"rwgxeegxbnjnczep\":{\"type\":\"Array\",\"defaultValue\":\"datamprklatwiuujxsuj\"},\"uyyaescjxna\":{\"type\":\"SecureString\",\"defaultValue\":\"dataymgbfmd\"},\"inzkefkzlxvc\":{\"type\":\"Float\",\"defaultValue\":\"dataxqbkxdtbfkih\"}},\"annotations\":[\"datagoeozlib\",\"databnunzuysajvvqlho\",\"datayonelivgtibtkqjq\",\"datacaj\"],\"folder\":{\"name\":\"y\"},\"\":{\"mrvkxeojtdyulglh\":\"datahk\",\"xspxgogypbztgae\":\"datalwruklfq\"}}")
.toObject(SapTableResourceDataset.class);
- Assertions.assertEquals("duwd", model.description());
- Assertions.assertEquals("s", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("pbkmzkwhjjs").type());
- Assertions.assertEquals("pfdfu", model.folder().name());
+ Assertions.assertEquals("dxuczl", model.description());
+ Assertions.assertEquals("kqwucqsd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("rwgxeegxbnjnczep").type());
+ Assertions.assertEquals("y", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapTableResourceDataset model = new SapTableResourceDataset().withDescription("duwd")
- .withStructure("datalxtqm")
- .withSchema("datac")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("s")
- .withParameters(mapOf("oxedrmrazhvch", "databkiumjf", "zsoowxcsmxtlcapp", "datavoyiogbntnwzr")))
- .withParameters(mapOf("pbkmzkwhjjs",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataspciryomhkdwuwed"),
- "vvkxdbnmc", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataaefe")))
- .withAnnotations(Arrays.asList("dataycdzdob", "dataesdyvf"))
- .withFolder(new DatasetFolder().withName("pfdfu"))
- .withTableName("dataxwjoqfzwand");
+ SapTableResourceDataset model = new SapTableResourceDataset().withDescription("dxuczl")
+ .withStructure("datab")
+ .withSchema("datacznrirpiiuvcqo")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("kqwucqsd")
+ .withParameters(mapOf("kjlamyvwprjmaiht", "datacwtvmijccp", "ppvolzayjw", "datanlbhxjppcbqetfz")))
+ .withParameters(mapOf("rwgxeegxbnjnczep",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datamprklatwiuujxsuj"),
+ "uyyaescjxna",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataymgbfmd"),
+ "inzkefkzlxvc",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataxqbkxdtbfkih")))
+ .withAnnotations(Arrays.asList("datagoeozlib", "databnunzuysajvvqlho", "datayonelivgtibtkqjq", "datacaj"))
+ .withFolder(new DatasetFolder().withName("y"))
+ .withTableName("datadngvnqdjgsbtwg");
model = BinaryData.fromObject(model).toObject(SapTableResourceDataset.class);
- Assertions.assertEquals("duwd", model.description());
- Assertions.assertEquals("s", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("pbkmzkwhjjs").type());
- Assertions.assertEquals("pfdfu", model.folder().name());
+ Assertions.assertEquals("dxuczl", model.description());
+ Assertions.assertEquals("kqwucqsd", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("rwgxeegxbnjnczep").type());
+ Assertions.assertEquals("y", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTypePropertiesTests.java
index a35d3b563a6a..6096a2d00fb9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableResourceDatasetTypePropertiesTests.java
@@ -10,14 +10,14 @@
public final class SapTableResourceDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SapTableResourceDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datawgsltutbuve\"}")
+ SapTableResourceDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datajnskvct\"}")
.toObject(SapTableResourceDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SapTableResourceDatasetTypeProperties model
- = new SapTableResourceDatasetTypeProperties().withTableName("datawgsltutbuve");
+ = new SapTableResourceDatasetTypeProperties().withTableName("datajnskvct");
model = BinaryData.fromObject(model).toObject(SapTableResourceDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableSourceTests.java
index e2d356ed4b19..e8c3f3a5e922 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SapTableSourceTests.java
@@ -12,30 +12,30 @@ public final class SapTableSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SapTableSource model = BinaryData.fromString(
- "{\"type\":\"SapTableSource\",\"rowCount\":\"dataujohwwtle\",\"rowSkips\":\"datapfr\",\"rfcTableFields\":\"dataqnjushsxhtvn\",\"rfcTableOptions\":\"datamrrgmlwgomhs\",\"batchSize\":\"datad\",\"customRfcReadTableFunctionModule\":\"datacn\",\"sapDataColumnDelimiter\":\"dataijxfcngeffrg\",\"partitionOption\":\"datadmrowhrrguvd\",\"partitionSettings\":{\"partitionColumnName\":\"dataucwawlms\",\"partitionUpperBound\":\"datalzomdfcphg\",\"partitionLowerBound\":\"dataijzhrb\",\"maxPartitionsNumber\":\"datajvublou\"},\"queryTimeout\":\"datafyqfbgeblp\",\"additionalColumns\":\"datackmnpzubz\",\"sourceRetryCount\":\"dataswgfjrg\",\"sourceRetryWait\":\"datacpbshqzzlcfe\",\"maxConcurrentConnections\":\"dataryxnklfswzsyigx\",\"disableMetricsCollection\":\"dataxhygc\",\"\":{\"suopcdiaossp\":\"dataapeuqyzf\",\"qgllnhgisiw\":\"datautgkmrsq\"}}")
+ "{\"type\":\"SapTableSource\",\"rowCount\":\"dataoukfjwkctdn\",\"rowSkips\":\"dataokqeuzslny\",\"rfcTableFields\":\"datauywijnlpeczq\",\"rfcTableOptions\":\"datamzkqydthf\",\"batchSize\":\"dataycmwvphrwuf\",\"customRfcReadTableFunctionModule\":\"dataov\",\"sapDataColumnDelimiter\":\"dataisqlekc\",\"partitionOption\":\"datadhlskeifwqtcownx\",\"partitionSettings\":{\"partitionColumnName\":\"dataptvbudb\",\"partitionUpperBound\":\"datajvmllyjelnhmu\",\"partitionLowerBound\":\"dataxkofzx\",\"maxPartitionsNumber\":\"datasleokbama\"},\"queryTimeout\":\"datawgccgblepamvl\",\"additionalColumns\":\"dataxdaoj\",\"sourceRetryCount\":\"datalqoxwqlnxvnmrl\",\"sourceRetryWait\":\"datajzya\",\"maxConcurrentConnections\":\"datafecwnufldzjc\",\"disableMetricsCollection\":\"datahjbzpoh\",\"\":{\"lnvfshtujaqp\":\"datagpefvboxvw\"}}")
.toObject(SapTableSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SapTableSource model = new SapTableSource().withSourceRetryCount("dataswgfjrg")
- .withSourceRetryWait("datacpbshqzzlcfe")
- .withMaxConcurrentConnections("dataryxnklfswzsyigx")
- .withDisableMetricsCollection("dataxhygc")
- .withQueryTimeout("datafyqfbgeblp")
- .withAdditionalColumns("datackmnpzubz")
- .withRowCount("dataujohwwtle")
- .withRowSkips("datapfr")
- .withRfcTableFields("dataqnjushsxhtvn")
- .withRfcTableOptions("datamrrgmlwgomhs")
- .withBatchSize("datad")
- .withCustomRfcReadTableFunctionModule("datacn")
- .withSapDataColumnDelimiter("dataijxfcngeffrg")
- .withPartitionOption("datadmrowhrrguvd")
- .withPartitionSettings(new SapTablePartitionSettings().withPartitionColumnName("dataucwawlms")
- .withPartitionUpperBound("datalzomdfcphg")
- .withPartitionLowerBound("dataijzhrb")
- .withMaxPartitionsNumber("datajvublou"));
+ SapTableSource model = new SapTableSource().withSourceRetryCount("datalqoxwqlnxvnmrl")
+ .withSourceRetryWait("datajzya")
+ .withMaxConcurrentConnections("datafecwnufldzjc")
+ .withDisableMetricsCollection("datahjbzpoh")
+ .withQueryTimeout("datawgccgblepamvl")
+ .withAdditionalColumns("dataxdaoj")
+ .withRowCount("dataoukfjwkctdn")
+ .withRowSkips("dataokqeuzslny")
+ .withRfcTableFields("datauywijnlpeczq")
+ .withRfcTableOptions("datamzkqydthf")
+ .withBatchSize("dataycmwvphrwuf")
+ .withCustomRfcReadTableFunctionModule("dataov")
+ .withSapDataColumnDelimiter("dataisqlekc")
+ .withPartitionOption("datadhlskeifwqtcownx")
+ .withPartitionSettings(new SapTablePartitionSettings().withPartitionColumnName("dataptvbudb")
+ .withPartitionUpperBound("datajvmllyjelnhmu")
+ .withPartitionLowerBound("dataxkofzx")
+ .withMaxPartitionsNumber("datasleokbama"));
model = BinaryData.fromObject(model).toObject(SapTableSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerRecurrenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerRecurrenceTests.java
index e1e3fc51ee89..bde36d167bae 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerRecurrenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerRecurrenceTests.java
@@ -21,51 +21,49 @@ public final class ScheduleTriggerRecurrenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScheduleTriggerRecurrence model = BinaryData.fromString(
- "{\"frequency\":\"Day\",\"interval\":697389679,\"startTime\":\"2021-06-28T09:45:44Z\",\"endTime\":\"2021-03-10T03:08:50Z\",\"timeZone\":\"jvikpgzkfjqo\",\"schedule\":{\"minutes\":[1987241147,1286210350,71551699,1632306199],\"hours\":[154490101],\"weekDays\":[\"Wednesday\",\"Friday\"],\"monthDays\":[1440767604,2068484249],\"monthlyOccurrences\":[{\"day\":\"Friday\",\"occurrence\":1634393493,\"\":{\"rwqrfejznz\":\"datatwzgbuh\"}}],\"\":{\"vsjiojvetlcqaa\":\"dataufs\",\"cbdkqrywv\":\"datauwxehozazb\"}},\"\":{\"gnhwhvgowkakdj\":\"datayccd\"}}")
+ "{\"frequency\":\"Minute\",\"interval\":1468937933,\"startTime\":\"2021-08-02T13:39:35Z\",\"endTime\":\"2021-02-16T06:48:38Z\",\"timeZone\":\"dxuzoxmajpxb\",\"schedule\":{\"minutes\":[711985239],\"hours\":[1240812360,1065282334,987445485,1494770482],\"weekDays\":[\"Monday\",\"Monday\",\"Sunday\"],\"monthDays\":[1235095597],\"monthlyOccurrences\":[{\"day\":\"Wednesday\",\"occurrence\":727069286,\"\":{\"lri\":\"dataivqaqzttog\"}}],\"\":{\"ql\":\"dataiqucolpos\",\"jpalnzrjqlqh\":\"datalwkj\",\"xhawsnqktbgu\":\"datayneyoxj\",\"tcupo\":\"datafcr\"}},\"\":{\"qkufqjmylrtnzyos\":\"datargcl\",\"w\":\"datavkqezeeeuligu\",\"cvwzywxzxrohtqcw\":\"datafk\",\"aiskecmc\":\"datadspegxd\"}}")
.toObject(ScheduleTriggerRecurrence.class);
- Assertions.assertEquals(RecurrenceFrequency.DAY, model.frequency());
- Assertions.assertEquals(697389679, model.interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-06-28T09:45:44Z"), model.startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-10T03:08:50Z"), model.endTime());
- Assertions.assertEquals("jvikpgzkfjqo", model.timeZone());
- Assertions.assertEquals(1987241147, model.schedule().minutes().get(0));
- Assertions.assertEquals(154490101, model.schedule().hours().get(0));
- Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.schedule().weekDays().get(0));
- Assertions.assertEquals(1440767604, model.schedule().monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.FRIDAY, model.schedule().monthlyOccurrences().get(0).day());
- Assertions.assertEquals(1634393493, model.schedule().monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals(RecurrenceFrequency.MINUTE, model.frequency());
+ Assertions.assertEquals(1468937933, model.interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-08-02T13:39:35Z"), model.startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-02-16T06:48:38Z"), model.endTime());
+ Assertions.assertEquals("dxuzoxmajpxb", model.timeZone());
+ Assertions.assertEquals(711985239, model.schedule().minutes().get(0));
+ Assertions.assertEquals(1240812360, model.schedule().hours().get(0));
+ Assertions.assertEquals(DaysOfWeek.MONDAY, model.schedule().weekDays().get(0));
+ Assertions.assertEquals(1235095597, model.schedule().monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.WEDNESDAY, model.schedule().monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(727069286, model.schedule().monthlyOccurrences().get(0).occurrence());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ScheduleTriggerRecurrence model
- = new ScheduleTriggerRecurrence().withFrequency(RecurrenceFrequency.DAY)
- .withInterval(697389679)
- .withStartTime(OffsetDateTime.parse("2021-06-28T09:45:44Z"))
- .withEndTime(OffsetDateTime.parse("2021-03-10T03:08:50Z"))
- .withTimeZone("jvikpgzkfjqo")
- .withSchedule(new RecurrenceSchedule()
- .withMinutes(Arrays.asList(1987241147, 1286210350, 71551699, 1632306199))
- .withHours(Arrays.asList(154490101))
- .withWeekDays(Arrays.asList(DaysOfWeek.WEDNESDAY, DaysOfWeek.FRIDAY))
- .withMonthDays(Arrays.asList(1440767604, 2068484249))
- .withMonthlyOccurrences(Arrays.asList(new RecurrenceScheduleOccurrence().withDay(DayOfWeek.FRIDAY)
- .withOccurrence(1634393493)
- .withAdditionalProperties(mapOf())))
- .withAdditionalProperties(mapOf()))
- .withAdditionalProperties(mapOf());
+ ScheduleTriggerRecurrence model = new ScheduleTriggerRecurrence().withFrequency(RecurrenceFrequency.MINUTE)
+ .withInterval(1468937933)
+ .withStartTime(OffsetDateTime.parse("2021-08-02T13:39:35Z"))
+ .withEndTime(OffsetDateTime.parse("2021-02-16T06:48:38Z"))
+ .withTimeZone("dxuzoxmajpxb")
+ .withSchedule(new RecurrenceSchedule().withMinutes(Arrays.asList(711985239))
+ .withHours(Arrays.asList(1240812360, 1065282334, 987445485, 1494770482))
+ .withWeekDays(Arrays.asList(DaysOfWeek.MONDAY, DaysOfWeek.MONDAY, DaysOfWeek.SUNDAY))
+ .withMonthDays(Arrays.asList(1235095597))
+ .withMonthlyOccurrences(Arrays.asList(new RecurrenceScheduleOccurrence().withDay(DayOfWeek.WEDNESDAY)
+ .withOccurrence(727069286)
+ .withAdditionalProperties(mapOf())))
+ .withAdditionalProperties(mapOf()))
+ .withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(ScheduleTriggerRecurrence.class);
- Assertions.assertEquals(RecurrenceFrequency.DAY, model.frequency());
- Assertions.assertEquals(697389679, model.interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-06-28T09:45:44Z"), model.startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-10T03:08:50Z"), model.endTime());
- Assertions.assertEquals("jvikpgzkfjqo", model.timeZone());
- Assertions.assertEquals(1987241147, model.schedule().minutes().get(0));
- Assertions.assertEquals(154490101, model.schedule().hours().get(0));
- Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.schedule().weekDays().get(0));
- Assertions.assertEquals(1440767604, model.schedule().monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.FRIDAY, model.schedule().monthlyOccurrences().get(0).day());
- Assertions.assertEquals(1634393493, model.schedule().monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals(RecurrenceFrequency.MINUTE, model.frequency());
+ Assertions.assertEquals(1468937933, model.interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-08-02T13:39:35Z"), model.startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-02-16T06:48:38Z"), model.endTime());
+ Assertions.assertEquals("dxuzoxmajpxb", model.timeZone());
+ Assertions.assertEquals(711985239, model.schedule().minutes().get(0));
+ Assertions.assertEquals(1240812360, model.schedule().hours().get(0));
+ Assertions.assertEquals(DaysOfWeek.MONDAY, model.schedule().weekDays().get(0));
+ Assertions.assertEquals(1235095597, model.schedule().monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.WEDNESDAY, model.schedule().monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(727069286, model.schedule().monthlyOccurrences().get(0).occurrence());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTests.java
index 0397298bb50d..d34158fb6098 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTests.java
@@ -24,81 +24,66 @@ public final class ScheduleTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScheduleTrigger model = BinaryData.fromString(
- "{\"type\":\"ScheduleTrigger\",\"typeProperties\":{\"recurrence\":{\"frequency\":\"Month\",\"interval\":651307046,\"startTime\":\"2021-03-30T07:03:18Z\",\"endTime\":\"2021-01-10T10:02:22Z\",\"timeZone\":\"kyvu\",\"schedule\":{\"minutes\":[283583616],\"hours\":[1458529863,199145977],\"weekDays\":[\"Tuesday\"],\"monthDays\":[496889567,1775005280],\"monthlyOccurrences\":[{\"day\":\"Friday\",\"occurrence\":663593930,\"\":{\"wmefpijwr\":\"datazcizuegyl\",\"acgrysjgz\":\"databuphbwaisw\",\"pfwfdcpeduxyddv\":\"datazojupdc\"}},{\"day\":\"Monday\",\"occurrence\":852699787,\"\":{\"ziapsypgmmie\":\"datankhgg\",\"ojargetncfl\":\"dataeqmtetnywgmeiiha\"}},{\"day\":\"Tuesday\",\"occurrence\":488432915,\"\":{\"naeefzlwohobaac\":\"datakcqe\",\"noeiqhbr\":\"dataglvixfl\",\"kpbrr\":\"datacgmyjmcw\",\"teblrnu\":\"databzvink\"}}],\"\":{\"musudhjoshmmzotc\":\"datan\",\"difbeott\":\"dataffmik\"}},\"\":{\"ut\":\"dataonejpjzqb\",\"atfalhnixo\":\"datanlow\"}}},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"b\",\"name\":\"jbeihcaxk\"},\"parameters\":{\"nfuvesmepqrkjyp\":\"datayvbcxnni\",\"fshfmw\":\"datasvnotbe\",\"g\":\"datatex\",\"odpm\":\"datandtjcyvmsd\"}},{\"pipelineReference\":{\"referenceName\":\"sggneocqaejle\",\"name\":\"ydpqwucprpwsg\"},\"parameters\":{\"bcto\":\"datakcikefwmqial\"}},{\"pipelineReference\":{\"referenceName\":\"ocepjsfhxhulrekr\",\"name\":\"jdnzrcj\"},\"parameters\":{\"vaoryefgwo\":\"datathydyzrrwlgueso\",\"zqvi\":\"datayceksdatjtgmf\",\"cocsmcqskrjnqaa\":\"datadhixd\"}},{\"pipelineReference\":{\"referenceName\":\"zjdrkc\",\"name\":\"eox\"},\"parameters\":{\"cqpvrrmlk\":\"dataztlxqhyyxhzgxk\"}}],\"description\":\"oqsdvxddsfylbok\",\"runtimeState\":\"Stopped\",\"annotations\":[\"datarxae\"],\"\":{\"zkumxbcnkoj\":\"dataravswnns\",\"cfjw\":\"datankhbt\"}}")
+ "{\"type\":\"ScheduleTrigger\",\"typeProperties\":{\"recurrence\":{\"frequency\":\"Minute\",\"interval\":1693781649,\"startTime\":\"2021-12-09T23:42:31Z\",\"endTime\":\"2021-10-30T05:40:14Z\",\"timeZone\":\"umjmpsxz\",\"schedule\":{\"minutes\":[1441509354,1208352481,15982153],\"hours\":[1683368107,1234651783],\"weekDays\":[\"Wednesday\",\"Friday\"],\"monthDays\":[343405067,1725868714,1760240817],\"monthlyOccurrences\":[{\"day\":\"Saturday\",\"occurrence\":101046964,\"\":{\"g\":\"dataxqtcnyhs\",\"zfyzbnko\":\"dataoxnelhx\",\"e\":\"datacsvipwa\",\"prgpm\":\"datauc\"}}],\"\":{\"zcsklvtcea\":\"datavuhcwc\",\"paywwesaqsuqpskv\":\"dataiuurqlcdhebjf\",\"lra\":\"datab\",\"thhxqsbyyleyopgy\":\"dataidi\"}},\"\":{\"gkpcwffoso\":\"datanyfjwoaom\"}}},\"pipelines\":[{\"pipelineReference\":{\"referenceName\":\"gjuzgqkx\",\"name\":\"avbteaegyojy\"},\"parameters\":{\"hbztlvujbhw\":\"datapcdhqjc\",\"cihkjjjbit\":\"dataszrhf\",\"fwmasodsmjn\":\"datauriizyrgzxpr\"}},{\"pipelineReference\":{\"referenceName\":\"doomhrlgidqxbrdh\",\"name\":\"cq\"},\"parameters\":{\"hienkliyfgkzwkyq\":\"datapjd\"}}],\"description\":\"diybdoyykhi\",\"runtimeState\":\"Stopped\",\"annotations\":[\"dataktwijoxkkynppqt\"],\"\":{\"wjatyhkqqj\":\"dataf\"}}")
.toObject(ScheduleTrigger.class);
- Assertions.assertEquals("oqsdvxddsfylbok", model.description());
- Assertions.assertEquals("b", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("jbeihcaxk", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals(RecurrenceFrequency.MONTH, model.recurrence().frequency());
- Assertions.assertEquals(651307046, model.recurrence().interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-30T07:03:18Z"), model.recurrence().startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-01-10T10:02:22Z"), model.recurrence().endTime());
- Assertions.assertEquals("kyvu", model.recurrence().timeZone());
- Assertions.assertEquals(283583616, model.recurrence().schedule().minutes().get(0));
- Assertions.assertEquals(1458529863, model.recurrence().schedule().hours().get(0));
- Assertions.assertEquals(DaysOfWeek.TUESDAY, model.recurrence().schedule().weekDays().get(0));
- Assertions.assertEquals(496889567, model.recurrence().schedule().monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.FRIDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
- Assertions.assertEquals(663593930, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals("diybdoyykhi", model.description());
+ Assertions.assertEquals("gjuzgqkx", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("avbteaegyojy", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals(RecurrenceFrequency.MINUTE, model.recurrence().frequency());
+ Assertions.assertEquals(1693781649, model.recurrence().interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-12-09T23:42:31Z"), model.recurrence().startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-10-30T05:40:14Z"), model.recurrence().endTime());
+ Assertions.assertEquals("umjmpsxz", model.recurrence().timeZone());
+ Assertions.assertEquals(1441509354, model.recurrence().schedule().minutes().get(0));
+ Assertions.assertEquals(1683368107, model.recurrence().schedule().hours().get(0));
+ Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.recurrence().schedule().weekDays().get(0));
+ Assertions.assertEquals(343405067, model.recurrence().schedule().monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.SATURDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(101046964, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ScheduleTrigger model = new ScheduleTrigger().withDescription("oqsdvxddsfylbok")
- .withAnnotations(Arrays.asList("datarxae"))
+ ScheduleTrigger model = new ScheduleTrigger().withDescription("diybdoyykhi")
+ .withAnnotations(Arrays.asList("dataktwijoxkkynppqt"))
.withPipelines(Arrays.asList(
- new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("b").withName("jbeihcaxk"))
- .withParameters(mapOf("nfuvesmepqrkjyp", "datayvbcxnni", "fshfmw", "datasvnotbe", "g", "datatex",
- "odpm", "datandtjcyvmsd")),
- new TriggerPipelineReference()
- .withPipelineReference(
- new PipelineReference().withReferenceName("sggneocqaejle").withName("ydpqwucprpwsg"))
- .withParameters(mapOf("bcto", "datakcikefwmqial")),
new TriggerPipelineReference()
.withPipelineReference(
- new PipelineReference().withReferenceName("ocepjsfhxhulrekr").withName("jdnzrcj"))
- .withParameters(mapOf("vaoryefgwo", "datathydyzrrwlgueso", "zqvi", "datayceksdatjtgmf",
- "cocsmcqskrjnqaa", "datadhixd")),
+ new PipelineReference().withReferenceName("gjuzgqkx").withName("avbteaegyojy"))
+ .withParameters(mapOf("hbztlvujbhw", "datapcdhqjc", "cihkjjjbit", "dataszrhf", "fwmasodsmjn",
+ "datauriizyrgzxpr")),
new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("zjdrkc").withName("eox"))
- .withParameters(mapOf("cqpvrrmlk", "dataztlxqhyyxhzgxk"))))
- .withRecurrence(new ScheduleTriggerRecurrence().withFrequency(RecurrenceFrequency.MONTH)
- .withInterval(651307046)
- .withStartTime(OffsetDateTime.parse("2021-03-30T07:03:18Z"))
- .withEndTime(OffsetDateTime.parse("2021-01-10T10:02:22Z"))
- .withTimeZone("kyvu")
- .withSchedule(new RecurrenceSchedule().withMinutes(Arrays.asList(283583616))
- .withHours(Arrays.asList(1458529863, 199145977))
- .withWeekDays(Arrays.asList(DaysOfWeek.TUESDAY))
- .withMonthDays(Arrays.asList(496889567, 1775005280))
- .withMonthlyOccurrences(Arrays.asList(
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.FRIDAY)
- .withOccurrence(663593930)
- .withAdditionalProperties(mapOf()),
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.MONDAY)
- .withOccurrence(852699787)
- .withAdditionalProperties(mapOf()),
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.TUESDAY)
- .withOccurrence(488432915)
- .withAdditionalProperties(mapOf())))
+ .withPipelineReference(new PipelineReference().withReferenceName("doomhrlgidqxbrdh").withName("cq"))
+ .withParameters(mapOf("hienkliyfgkzwkyq", "datapjd"))))
+ .withRecurrence(new ScheduleTriggerRecurrence().withFrequency(RecurrenceFrequency.MINUTE)
+ .withInterval(1693781649)
+ .withStartTime(OffsetDateTime.parse("2021-12-09T23:42:31Z"))
+ .withEndTime(OffsetDateTime.parse("2021-10-30T05:40:14Z"))
+ .withTimeZone("umjmpsxz")
+ .withSchedule(new RecurrenceSchedule().withMinutes(Arrays.asList(1441509354, 1208352481, 15982153))
+ .withHours(Arrays.asList(1683368107, 1234651783))
+ .withWeekDays(Arrays.asList(DaysOfWeek.WEDNESDAY, DaysOfWeek.FRIDAY))
+ .withMonthDays(Arrays.asList(343405067, 1725868714, 1760240817))
+ .withMonthlyOccurrences(Arrays.asList(new RecurrenceScheduleOccurrence().withDay(DayOfWeek.SATURDAY)
+ .withOccurrence(101046964)
+ .withAdditionalProperties(mapOf())))
.withAdditionalProperties(mapOf()))
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(ScheduleTrigger.class);
- Assertions.assertEquals("oqsdvxddsfylbok", model.description());
- Assertions.assertEquals("b", model.pipelines().get(0).pipelineReference().referenceName());
- Assertions.assertEquals("jbeihcaxk", model.pipelines().get(0).pipelineReference().name());
- Assertions.assertEquals(RecurrenceFrequency.MONTH, model.recurrence().frequency());
- Assertions.assertEquals(651307046, model.recurrence().interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-30T07:03:18Z"), model.recurrence().startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-01-10T10:02:22Z"), model.recurrence().endTime());
- Assertions.assertEquals("kyvu", model.recurrence().timeZone());
- Assertions.assertEquals(283583616, model.recurrence().schedule().minutes().get(0));
- Assertions.assertEquals(1458529863, model.recurrence().schedule().hours().get(0));
- Assertions.assertEquals(DaysOfWeek.TUESDAY, model.recurrence().schedule().weekDays().get(0));
- Assertions.assertEquals(496889567, model.recurrence().schedule().monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.FRIDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
- Assertions.assertEquals(663593930, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals("diybdoyykhi", model.description());
+ Assertions.assertEquals("gjuzgqkx", model.pipelines().get(0).pipelineReference().referenceName());
+ Assertions.assertEquals("avbteaegyojy", model.pipelines().get(0).pipelineReference().name());
+ Assertions.assertEquals(RecurrenceFrequency.MINUTE, model.recurrence().frequency());
+ Assertions.assertEquals(1693781649, model.recurrence().interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-12-09T23:42:31Z"), model.recurrence().startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-10-30T05:40:14Z"), model.recurrence().endTime());
+ Assertions.assertEquals("umjmpsxz", model.recurrence().timeZone());
+ Assertions.assertEquals(1441509354, model.recurrence().schedule().minutes().get(0));
+ Assertions.assertEquals(1683368107, model.recurrence().schedule().hours().get(0));
+ Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.recurrence().schedule().weekDays().get(0));
+ Assertions.assertEquals(343405067, model.recurrence().schedule().monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.SATURDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(101046964, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTypePropertiesTests.java
index 4978b29fd0ce..47421ba6216b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScheduleTriggerTypePropertiesTests.java
@@ -22,60 +22,58 @@ public final class ScheduleTriggerTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScheduleTriggerTypeProperties model = BinaryData.fromString(
- "{\"recurrence\":{\"frequency\":\"Hour\",\"interval\":533467013,\"startTime\":\"2021-06-20T15:09:23Z\",\"endTime\":\"2021-03-03T14:47:12Z\",\"timeZone\":\"oybpwzniekedxvw\",\"schedule\":{\"minutes\":[1538399987,35267670],\"hours\":[1480328857,950138743],\"weekDays\":[\"Wednesday\",\"Thursday\"],\"monthDays\":[1634562610,2079790685,1537807512,220269478],\"monthlyOccurrences\":[{\"day\":\"Thursday\",\"occurrence\":1191416818,\"\":{\"lsptzqaz\":\"datau\",\"jvyrdownbwrnb\":\"dataybbe\",\"smpcajx\":\"datacblmzaru\"}},{\"day\":\"Monday\",\"occurrence\":1892755426,\"\":{\"zckgbpysgzgiv\":\"datarjlwrqhehn\",\"jxxjaafr\":\"dataahektwgiumcco\",\"cnzsimbgv\":\"datadhrkhfyaxi\",\"rbogzwwyub\":\"dataksjjqqp\"}},{\"day\":\"Tuesday\",\"occurrence\":675719748,\"\":{\"byjfeanbnw\":\"datajqemgbkjxuxmkk\",\"fkzlv\":\"dataekpgllezvrvjws\"}},{\"day\":\"Tuesday\",\"occurrence\":88943257,\"\":{\"lrvquw\":\"datajynvguhqugnqs\"}}],\"\":{\"cfinsoimxxs\":\"datace\",\"xzogclusicnck\":\"databtpq\",\"r\":\"dataxflgjibtc\",\"errpal\":\"datal\"}},\"\":{\"u\":\"datasbgj\",\"hhkwlmittpbivh\":\"datazfjmnabyvm\",\"xplbdazsjbg\":\"datadxhnvy\",\"ihgbtn\":\"datadzzukhlwvvhovkad\"}}}")
+ "{\"recurrence\":{\"frequency\":\"Week\",\"interval\":1320814252,\"startTime\":\"2021-03-10T17:47:55Z\",\"endTime\":\"2021-04-17T10:32:31Z\",\"timeZone\":\"w\",\"schedule\":{\"minutes\":[1617858361],\"hours\":[653605955],\"weekDays\":[\"Wednesday\",\"Saturday\",\"Thursday\",\"Saturday\"],\"monthDays\":[1144219681,1904876430,794780703,1779734438],\"monthlyOccurrences\":[{\"day\":\"Friday\",\"occurrence\":1553291833,\"\":{\"pmvppg\":\"datauvshguu\",\"vafbdzokplolcal\":\"dataiyo\",\"tdqsqb\":\"datavcxvcpxdeqntb\",\"spzwa\":\"dataubswzafqrmwdofg\"}},{\"day\":\"Tuesday\",\"occurrence\":851506626,\"\":{\"nvhtrfckrm\":\"datacdjvlwczwdkkscoo\",\"ghjsxpptsvppf\":\"databaoidtfmpcbvko\",\"scgzqncd\":\"datanihxcijftsbpvy\"}},{\"day\":\"Thursday\",\"occurrence\":1309388141,\"\":{\"rohfv\":\"datayi\",\"nkkztjmqjrh\":\"datagjnexdlsangl\"}}],\"\":{\"ozwnpuyhqaylsmeh\":\"dataajyrhrywucpdzbnt\",\"efofujzwqpkhgr\":\"datazplzrrhabbdq\",\"qkv\":\"datagyiloe\",\"aoetrglpaocq\":\"datafnphbzs\"}},\"\":{\"vuhagoqxfxje\":\"dataleou\",\"hrymeynbiwowu\":\"datauoquacrdn\",\"rnwkt\":\"datakiocjn\"}}}")
.toObject(ScheduleTriggerTypeProperties.class);
- Assertions.assertEquals(RecurrenceFrequency.HOUR, model.recurrence().frequency());
- Assertions.assertEquals(533467013, model.recurrence().interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-06-20T15:09:23Z"), model.recurrence().startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-03T14:47:12Z"), model.recurrence().endTime());
- Assertions.assertEquals("oybpwzniekedxvw", model.recurrence().timeZone());
- Assertions.assertEquals(1538399987, model.recurrence().schedule().minutes().get(0));
- Assertions.assertEquals(1480328857, model.recurrence().schedule().hours().get(0));
+ Assertions.assertEquals(RecurrenceFrequency.WEEK, model.recurrence().frequency());
+ Assertions.assertEquals(1320814252, model.recurrence().interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-03-10T17:47:55Z"), model.recurrence().startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-04-17T10:32:31Z"), model.recurrence().endTime());
+ Assertions.assertEquals("w", model.recurrence().timeZone());
+ Assertions.assertEquals(1617858361, model.recurrence().schedule().minutes().get(0));
+ Assertions.assertEquals(653605955, model.recurrence().schedule().hours().get(0));
Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.recurrence().schedule().weekDays().get(0));
- Assertions.assertEquals(1634562610, model.recurrence().schedule().monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.THURSDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
- Assertions.assertEquals(1191416818, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals(1144219681, model.recurrence().schedule().monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.FRIDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(1553291833, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
ScheduleTriggerTypeProperties model = new ScheduleTriggerTypeProperties()
- .withRecurrence(new ScheduleTriggerRecurrence().withFrequency(RecurrenceFrequency.HOUR)
- .withInterval(533467013)
- .withStartTime(OffsetDateTime.parse("2021-06-20T15:09:23Z"))
- .withEndTime(OffsetDateTime.parse("2021-03-03T14:47:12Z"))
- .withTimeZone("oybpwzniekedxvw")
- .withSchedule(new RecurrenceSchedule().withMinutes(Arrays.asList(1538399987, 35267670))
- .withHours(Arrays.asList(1480328857, 950138743))
- .withWeekDays(Arrays.asList(DaysOfWeek.WEDNESDAY, DaysOfWeek.THURSDAY))
- .withMonthDays(Arrays.asList(1634562610, 2079790685, 1537807512, 220269478))
+ .withRecurrence(new ScheduleTriggerRecurrence().withFrequency(RecurrenceFrequency.WEEK)
+ .withInterval(1320814252)
+ .withStartTime(OffsetDateTime.parse("2021-03-10T17:47:55Z"))
+ .withEndTime(OffsetDateTime.parse("2021-04-17T10:32:31Z"))
+ .withTimeZone("w")
+ .withSchedule(new RecurrenceSchedule().withMinutes(Arrays.asList(1617858361))
+ .withHours(Arrays.asList(653605955))
+ .withWeekDays(Arrays.asList(DaysOfWeek.WEDNESDAY, DaysOfWeek.SATURDAY, DaysOfWeek.THURSDAY,
+ DaysOfWeek.SATURDAY))
+ .withMonthDays(Arrays.asList(1144219681, 1904876430, 794780703, 1779734438))
.withMonthlyOccurrences(Arrays.asList(
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.THURSDAY)
- .withOccurrence(1191416818)
- .withAdditionalProperties(mapOf()),
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.MONDAY)
- .withOccurrence(1892755426)
+ new RecurrenceScheduleOccurrence().withDay(DayOfWeek.FRIDAY)
+ .withOccurrence(1553291833)
.withAdditionalProperties(mapOf()),
new RecurrenceScheduleOccurrence().withDay(DayOfWeek.TUESDAY)
- .withOccurrence(675719748)
+ .withOccurrence(851506626)
.withAdditionalProperties(mapOf()),
- new RecurrenceScheduleOccurrence().withDay(DayOfWeek.TUESDAY)
- .withOccurrence(88943257)
+ new RecurrenceScheduleOccurrence().withDay(DayOfWeek.THURSDAY)
+ .withOccurrence(1309388141)
.withAdditionalProperties(mapOf())))
.withAdditionalProperties(mapOf()))
.withAdditionalProperties(mapOf()));
model = BinaryData.fromObject(model).toObject(ScheduleTriggerTypeProperties.class);
- Assertions.assertEquals(RecurrenceFrequency.HOUR, model.recurrence().frequency());
- Assertions.assertEquals(533467013, model.recurrence().interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-06-20T15:09:23Z"), model.recurrence().startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-03-03T14:47:12Z"), model.recurrence().endTime());
- Assertions.assertEquals("oybpwzniekedxvw", model.recurrence().timeZone());
- Assertions.assertEquals(1538399987, model.recurrence().schedule().minutes().get(0));
- Assertions.assertEquals(1480328857, model.recurrence().schedule().hours().get(0));
+ Assertions.assertEquals(RecurrenceFrequency.WEEK, model.recurrence().frequency());
+ Assertions.assertEquals(1320814252, model.recurrence().interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-03-10T17:47:55Z"), model.recurrence().startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-04-17T10:32:31Z"), model.recurrence().endTime());
+ Assertions.assertEquals("w", model.recurrence().timeZone());
+ Assertions.assertEquals(1617858361, model.recurrence().schedule().minutes().get(0));
+ Assertions.assertEquals(653605955, model.recurrence().schedule().hours().get(0));
Assertions.assertEquals(DaysOfWeek.WEDNESDAY, model.recurrence().schedule().weekDays().get(0));
- Assertions.assertEquals(1634562610, model.recurrence().schedule().monthDays().get(0));
- Assertions.assertEquals(DayOfWeek.THURSDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
- Assertions.assertEquals(1191416818, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
+ Assertions.assertEquals(1144219681, model.recurrence().schedule().monthDays().get(0));
+ Assertions.assertEquals(DayOfWeek.FRIDAY, model.recurrence().schedule().monthlyOccurrences().get(0).day());
+ Assertions.assertEquals(1553291833, model.recurrence().schedule().monthlyOccurrences().get(0).occurrence());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActionTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActionTests.java
index 1e2900a6cc83..262d6f508c35 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActionTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActionTests.java
@@ -11,21 +11,23 @@
public final class ScriptActionTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- ScriptAction model = BinaryData
- .fromString("{\"name\":\"v\",\"uri\":\"xjqru\",\"roles\":\"datak\",\"parameters\":\"qyfecnsqeewfuwgm\"}")
+ ScriptAction model = BinaryData.fromString(
+ "{\"name\":\"jttzfswohddliikk\",\"uri\":\"sqpli\",\"roles\":\"datagemtnbkevuuky\",\"parameters\":\"ksncrzbtlrbzqt\"}")
.toObject(ScriptAction.class);
- Assertions.assertEquals("v", model.name());
- Assertions.assertEquals("xjqru", model.uri());
- Assertions.assertEquals("qyfecnsqeewfuwgm", model.parameters());
+ Assertions.assertEquals("jttzfswohddliikk", model.name());
+ Assertions.assertEquals("sqpli", model.uri());
+ Assertions.assertEquals("ksncrzbtlrbzqt", model.parameters());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ScriptAction model
- = new ScriptAction().withName("v").withUri("xjqru").withRoles("datak").withParameters("qyfecnsqeewfuwgm");
+ ScriptAction model = new ScriptAction().withName("jttzfswohddliikk")
+ .withUri("sqpli")
+ .withRoles("datagemtnbkevuuky")
+ .withParameters("ksncrzbtlrbzqt");
model = BinaryData.fromObject(model).toObject(ScriptAction.class);
- Assertions.assertEquals("v", model.name());
- Assertions.assertEquals("xjqru", model.uri());
- Assertions.assertEquals("qyfecnsqeewfuwgm", model.parameters());
+ Assertions.assertEquals("jttzfswohddliikk", model.name());
+ Assertions.assertEquals("sqpli", model.uri());
+ Assertions.assertEquals("ksncrzbtlrbzqt", model.parameters());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityParameterTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityParameterTests.java
index 00ac6052b670..0c4577aee067 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityParameterTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityParameterTests.java
@@ -14,23 +14,23 @@ public final class ScriptActivityParameterTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScriptActivityParameter model = BinaryData.fromString(
- "{\"name\":\"datawtxtetwqklz\",\"type\":\"Boolean\",\"value\":\"datazwlrhrvkneozpl\",\"direction\":\"InputOutput\",\"size\":1399462246}")
+ "{\"name\":\"dataanifcfr\",\"type\":\"Double\",\"value\":\"datasumgzebqbdewepo\",\"direction\":\"Output\",\"size\":487257197}")
.toObject(ScriptActivityParameter.class);
- Assertions.assertEquals(ScriptActivityParameterType.BOOLEAN, model.type());
- Assertions.assertEquals(ScriptActivityParameterDirection.INPUT_OUTPUT, model.direction());
- Assertions.assertEquals(1399462246, model.size());
+ Assertions.assertEquals(ScriptActivityParameterType.DOUBLE, model.type());
+ Assertions.assertEquals(ScriptActivityParameterDirection.OUTPUT, model.direction());
+ Assertions.assertEquals(487257197, model.size());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ScriptActivityParameter model = new ScriptActivityParameter().withName("datawtxtetwqklz")
- .withType(ScriptActivityParameterType.BOOLEAN)
- .withValue("datazwlrhrvkneozpl")
- .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
- .withSize(1399462246);
+ ScriptActivityParameter model = new ScriptActivityParameter().withName("dataanifcfr")
+ .withType(ScriptActivityParameterType.DOUBLE)
+ .withValue("datasumgzebqbdewepo")
+ .withDirection(ScriptActivityParameterDirection.OUTPUT)
+ .withSize(487257197);
model = BinaryData.fromObject(model).toObject(ScriptActivityParameter.class);
- Assertions.assertEquals(ScriptActivityParameterType.BOOLEAN, model.type());
- Assertions.assertEquals(ScriptActivityParameterDirection.INPUT_OUTPUT, model.direction());
- Assertions.assertEquals(1399462246, model.size());
+ Assertions.assertEquals(ScriptActivityParameterType.DOUBLE, model.type());
+ Assertions.assertEquals(ScriptActivityParameterDirection.OUTPUT, model.direction());
+ Assertions.assertEquals(487257197, model.size());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityScriptBlockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityScriptBlockTests.java
index 4afcc8b67f92..fd292695c8e2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityScriptBlockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityScriptBlockTests.java
@@ -16,25 +16,36 @@ public final class ScriptActivityScriptBlockTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScriptActivityScriptBlock model = BinaryData.fromString(
- "{\"text\":\"datad\",\"type\":\"datasybn\",\"parameters\":[{\"name\":\"datak\",\"type\":\"DateTime\",\"value\":\"datavrqkmpqs\",\"direction\":\"Output\",\"size\":1973473232}]}")
+ "{\"text\":\"datagwwrclxhveso\",\"type\":\"datadxmmtyumejp\",\"parameters\":[{\"name\":\"dataodwblaujhox\",\"type\":\"Guid\",\"value\":\"dataeuywyamtzl\",\"direction\":\"InputOutput\",\"size\":1167066365},{\"name\":\"dataqjbjdyoc\",\"type\":\"Guid\",\"value\":\"datayhi\",\"direction\":\"Input\",\"size\":1743108327},{\"name\":\"datalsqymvihhgpe\",\"type\":\"Single\",\"value\":\"datakkhyfiuxda\",\"direction\":\"InputOutput\",\"size\":246649999}]}")
.toObject(ScriptActivityScriptBlock.class);
- Assertions.assertEquals(ScriptActivityParameterType.DATE_TIME, model.parameters().get(0).type());
- Assertions.assertEquals(ScriptActivityParameterDirection.OUTPUT, model.parameters().get(0).direction());
- Assertions.assertEquals(1973473232, model.parameters().get(0).size());
+ Assertions.assertEquals(ScriptActivityParameterType.GUID, model.parameters().get(0).type());
+ Assertions.assertEquals(ScriptActivityParameterDirection.INPUT_OUTPUT, model.parameters().get(0).direction());
+ Assertions.assertEquals(1167066365, model.parameters().get(0).size());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ScriptActivityScriptBlock model = new ScriptActivityScriptBlock().withText("datad")
- .withType("datasybn")
- .withParameters(Arrays.asList(new ScriptActivityParameter().withName("datak")
- .withType(ScriptActivityParameterType.DATE_TIME)
- .withValue("datavrqkmpqs")
- .withDirection(ScriptActivityParameterDirection.OUTPUT)
- .withSize(1973473232)));
+ ScriptActivityScriptBlock model = new ScriptActivityScriptBlock().withText("datagwwrclxhveso")
+ .withType("datadxmmtyumejp")
+ .withParameters(Arrays.asList(
+ new ScriptActivityParameter().withName("dataodwblaujhox")
+ .withType(ScriptActivityParameterType.GUID)
+ .withValue("dataeuywyamtzl")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(1167066365),
+ new ScriptActivityParameter().withName("dataqjbjdyoc")
+ .withType(ScriptActivityParameterType.GUID)
+ .withValue("datayhi")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(1743108327),
+ new ScriptActivityParameter().withName("datalsqymvihhgpe")
+ .withType(ScriptActivityParameterType.SINGLE)
+ .withValue("datakkhyfiuxda")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(246649999)));
model = BinaryData.fromObject(model).toObject(ScriptActivityScriptBlock.class);
- Assertions.assertEquals(ScriptActivityParameterType.DATE_TIME, model.parameters().get(0).type());
- Assertions.assertEquals(ScriptActivityParameterDirection.OUTPUT, model.parameters().get(0).direction());
- Assertions.assertEquals(1973473232, model.parameters().get(0).size());
+ Assertions.assertEquals(ScriptActivityParameterType.GUID, model.parameters().get(0).type());
+ Assertions.assertEquals(ScriptActivityParameterDirection.INPUT_OUTPUT, model.parameters().get(0).direction());
+ Assertions.assertEquals(1167066365, model.parameters().get(0).size());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTests.java
index f54de716d3ca..f92b25dbdf19 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTests.java
@@ -29,103 +29,138 @@ public final class ScriptActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScriptActivity model = BinaryData.fromString(
- "{\"type\":\"Script\",\"typeProperties\":{\"scriptBlockExecutionTimeout\":\"datafv\",\"scripts\":[{\"text\":\"datalxbpxzducfzdpgtb\",\"type\":\"datatibpg\",\"parameters\":[{\"name\":\"dataujfputci\",\"type\":\"String\",\"value\":\"datapksjwaglhwnnfgy\",\"direction\":\"Input\",\"size\":2133630125},{\"name\":\"datakmwvqtmfq\",\"type\":\"Int32\",\"value\":\"dataeljytshjjbocuu\",\"direction\":\"InputOutput\",\"size\":472367966},{\"name\":\"datahezhezyhwo\",\"type\":\"Boolean\",\"value\":\"datash\",\"direction\":\"InputOutput\",\"size\":950117586}]}],\"logSettings\":{\"logDestination\":\"ExternalStore\",\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"zeylthdrnzeidblr\",\"parameters\":{\"icwgdivq\":\"datafcck\",\"zomsqebmfopely\":\"databvgcebutskdgsuht\",\"bosnlaxeozgjtuh\":\"dataulia\",\"ptoentuve\":\"datagmshuyqehbpr\"}},\"path\":\"datatlfbzlzi\"}}},\"linkedServiceName\":{\"referenceName\":\"qlxwretsphetrq\",\"parameters\":{\"xkdiwpa\":\"datazrbgqtjjiearyz\",\"lhphurza\":\"dataumel\",\"vvrditghbaqumql\":\"datacukgmtrnwwww\"}},\"policy\":{\"timeout\":\"datasizerzygkdl\",\"retry\":\"dataltqryaahltto\",\"retryIntervalInSeconds\":1054322566,\"secureInput\":true,\"secureOutput\":false,\"\":{\"sgikvsnfn\":\"datavoeuiwyptzefeo\",\"aypbvgwylta\":\"datafsfgabdumhpbcix\"}},\"name\":\"n\",\"description\":\"elxmulyal\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"fdyawetkrmq\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Skipped\",\"Succeeded\"],\"\":{\"dceimlu\":\"dataxtnlor\",\"oxrj\":\"dataqxjxqqbkfdnski\",\"aufhxeeebcxeecgf\":\"datagmscic\"}},{\"activity\":\"ldjipayy\",\"dependencyConditions\":[\"Failed\"],\"\":{\"wltkukmdeqr\":\"datayyltn\",\"ijevf\":\"datauam\",\"xtkvpejtdlqorcyp\":\"datanvuokwjmtehpfn\"}},{\"activity\":\"kwfalgzsgk\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Completed\"],\"\":{\"vhhayqxlcrsho\":\"datahiqgihdu\"}}],\"userProperties\":[{\"name\":\"enobfviscauudx\",\"value\":\"datacvtzrgcmxbrf\"},{\"name\":\"iekwfx\",\"value\":\"datadotdgvsoypgqoqvc\"}],\"\":{\"uhbkapbgmjodfs\":\"dataypzcql\",\"gvsjuvjmnsgv\":\"datahlipxkxhj\",\"lvglwxepiwpi\":\"datayhomd\"}}")
+ "{\"type\":\"Script\",\"typeProperties\":{\"scriptBlockExecutionTimeout\":\"datavkzg\",\"scripts\":[{\"text\":\"datanvfekj\",\"type\":\"dataclbkkjz\",\"parameters\":[{\"name\":\"datalsjftqahfvpmw\",\"type\":\"Int64\",\"value\":\"datacjnkawkyh\",\"direction\":\"Input\",\"size\":53251602},{\"name\":\"datapbzktk\",\"type\":\"Double\",\"value\":\"datamjtgzu\",\"direction\":\"Output\",\"size\":2076493341}]},{\"text\":\"datal\",\"type\":\"dataj\",\"parameters\":[{\"name\":\"databbon\",\"type\":\"Guid\",\"value\":\"datafseykprgpqnesu\",\"direction\":\"Output\",\"size\":1419451177},{\"name\":\"datazadpwhldx\",\"type\":\"Int32\",\"value\":\"datatt\",\"direction\":\"Input\",\"size\":995318961},{\"name\":\"datagzssg\",\"type\":\"Boolean\",\"value\":\"datavqetvcxabzwehvs\",\"direction\":\"InputOutput\",\"size\":905453692},{\"name\":\"datahiaomldtkqoajp\",\"type\":\"Int32\",\"value\":\"dataafhz\",\"direction\":\"Output\",\"size\":1911604908}]},{\"text\":\"dataozqusdznnhh\",\"type\":\"datadfyusiupdmbh\",\"parameters\":[{\"name\":\"datawgteroaenvjouz\",\"type\":\"Int64\",\"value\":\"databraqzrbvogfm\",\"direction\":\"InputOutput\",\"size\":1572339861},{\"name\":\"datanlqnklbwyqoyp\",\"type\":\"Int32\",\"value\":\"dataajxmgxsp\",\"direction\":\"Input\",\"size\":779229082}]}],\"logSettings\":{\"logDestination\":\"ActivityOutput\",\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"kwvjo\",\"parameters\":{\"cloyvr\":\"dataaiydjgkdjmylhcjx\",\"bkigzvugwbc\":\"datazepnlwuhtfabafk\",\"ixp\":\"dataabsqpttulhanjui\",\"sk\":\"datatfdujuoiien\"}},\"path\":\"dataaqb\"}},\"returnMultistatementResult\":\"datacnbnlpp\"},\"linkedServiceName\":{\"referenceName\":\"bipfazsayrk\",\"parameters\":{\"nymdswrtifx\":\"datanobc\",\"vkx\":\"datahu\",\"vzrxaixx\":\"datanovk\"}},\"policy\":{\"timeout\":\"datas\",\"retry\":\"dataivpuuvz\",\"retryIntervalInSeconds\":662631486,\"secureInput\":false,\"secureOutput\":true,\"\":{\"jfmh\":\"datajaktszrcirrphtj\",\"gpqfflswqehtfr\":\"datadnxrwgd\"}},\"name\":\"zqeinnbu\",\"description\":\"vtykfxoss\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"l\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Skipped\",\"Failed\"],\"\":{\"rnkxswohshnc\":\"datawpgwpulrtjweuoro\",\"wdl\":\"datadzvlitntdidhhac\"}},{\"activity\":\"tgiontv\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"bgoe\":\"datahkqthuijvivtwswp\",\"fsfuzqpigirnmd\":\"datauxo\"}},{\"activity\":\"imagmwyfx\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\"],\"\":{\"ertgq\":\"datakllbfnn\",\"dkjayi\":\"datajcyhvyrhgeuvujyw\",\"jpgwseulfzxgh\":\"dataxpcxylquowunwac\"}}],\"userProperties\":[{\"name\":\"rvpaumkzd\",\"value\":\"datajngkfipxolpujlmb\"},{\"name\":\"jnalsbxvoux\",\"value\":\"datadenthgpwrmevk\"},{\"name\":\"kocexhlv\",\"value\":\"datanir\"}],\"\":{\"xjhzwsjqrmxpyz\":\"dataarohw\",\"tpczzqusf\":\"databamnkgmosayfyvod\",\"gij\":\"datagwsrr\"}}")
.toObject(ScriptActivity.class);
- Assertions.assertEquals("n", model.name());
- Assertions.assertEquals("elxmulyal", model.description());
+ Assertions.assertEquals("zqeinnbu", model.name());
+ Assertions.assertEquals("vtykfxoss", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("fdyawetkrmq", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("enobfviscauudx", model.userProperties().get(0).name());
- Assertions.assertEquals("qlxwretsphetrq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1054322566, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(ScriptActivityParameterType.STRING, model.scripts().get(0).parameters().get(0).type());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("l", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("rvpaumkzd", model.userProperties().get(0).name());
+ Assertions.assertEquals("bipfazsayrk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(662631486, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(ScriptActivityParameterType.INT64, model.scripts().get(0).parameters().get(0).type());
Assertions.assertEquals(ScriptActivityParameterDirection.INPUT,
model.scripts().get(0).parameters().get(0).direction());
- Assertions.assertEquals(2133630125, model.scripts().get(0).parameters().get(0).size());
- Assertions.assertEquals(ScriptActivityLogDestination.EXTERNAL_STORE, model.logSettings().logDestination());
- Assertions.assertEquals("zeylthdrnzeidblr",
- model.logSettings().logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals(53251602, model.scripts().get(0).parameters().get(0).size());
+ Assertions.assertEquals(ScriptActivityLogDestination.ACTIVITY_OUTPUT, model.logSettings().logDestination());
+ Assertions.assertEquals("kwvjo", model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ScriptActivity model = new ScriptActivity().withName("n")
- .withDescription("elxmulyal")
+ ScriptActivity model = new ScriptActivity().withName("zqeinnbu")
+ .withDescription("vtykfxoss")
.withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("fdyawetkrmq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("l")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ldjipayy")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("tgiontv")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("kwfalgzsgk")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED,
- DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("imagmwyfx")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf())))
.withUserProperties(
- Arrays.asList(new UserProperty().withName("enobfviscauudx").withValue("datacvtzrgcmxbrf"),
- new UserProperty().withName("iekwfx").withValue("datadotdgvsoypgqoqvc")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qlxwretsphetrq")
- .withParameters(mapOf("xkdiwpa", "datazrbgqtjjiearyz", "lhphurza", "dataumel", "vvrditghbaqumql",
- "datacukgmtrnwwww")))
- .withPolicy(new ActivityPolicy().withTimeout("datasizerzygkdl")
- .withRetry("dataltqryaahltto")
- .withRetryIntervalInSeconds(1054322566)
- .withSecureInput(true)
- .withSecureOutput(false)
+ Arrays.asList(new UserProperty().withName("rvpaumkzd").withValue("datajngkfipxolpujlmb"),
+ new UserProperty().withName("jnalsbxvoux").withValue("datadenthgpwrmevk"),
+ new UserProperty().withName("kocexhlv").withValue("datanir")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bipfazsayrk")
+ .withParameters(mapOf("nymdswrtifx", "datanobc", "vkx", "datahu", "vzrxaixx", "datanovk")))
+ .withPolicy(new ActivityPolicy().withTimeout("datas")
+ .withRetry("dataivpuuvz")
+ .withRetryIntervalInSeconds(662631486)
+ .withSecureInput(false)
+ .withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withScriptBlockExecutionTimeout("datafv")
- .withScripts(Arrays.asList(new ScriptActivityScriptBlock().withText("datalxbpxzducfzdpgtb")
- .withType("datatibpg")
- .withParameters(Arrays.asList(
- new ScriptActivityParameter().withName("dataujfputci")
- .withType(ScriptActivityParameterType.STRING)
- .withValue("datapksjwaglhwnnfgy")
- .withDirection(ScriptActivityParameterDirection.INPUT)
- .withSize(2133630125),
- new ScriptActivityParameter().withName("datakmwvqtmfq")
- .withType(ScriptActivityParameterType.INT32)
- .withValue("dataeljytshjjbocuu")
- .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
- .withSize(472367966),
- new ScriptActivityParameter().withName("datahezhezyhwo")
- .withType(ScriptActivityParameterType.BOOLEAN)
- .withValue("datash")
- .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
- .withSize(950117586)))))
- .withLogSettings(new ScriptActivityTypePropertiesLogSettings()
- .withLogDestination(ScriptActivityLogDestination.EXTERNAL_STORE)
- .withLogLocationSettings(new LogLocationSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zeylthdrnzeidblr")
- .withParameters(mapOf("icwgdivq", "datafcck", "zomsqebmfopely", "databvgcebutskdgsuht",
- "bosnlaxeozgjtuh", "dataulia", "ptoentuve", "datagmshuyqehbpr")))
- .withPath("datatlfbzlzi")));
+ .withScriptBlockExecutionTimeout("datavkzg")
+ .withScripts(
+ Arrays
+ .asList(
+ new ScriptActivityScriptBlock().withText("datanvfekj")
+ .withType("dataclbkkjz")
+ .withParameters(Arrays.asList(
+ new ScriptActivityParameter().withName("datalsjftqahfvpmw")
+ .withType(ScriptActivityParameterType.INT64)
+ .withValue("datacjnkawkyh")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(53251602),
+ new ScriptActivityParameter().withName("datapbzktk")
+ .withType(ScriptActivityParameterType.DOUBLE)
+ .withValue("datamjtgzu")
+ .withDirection(ScriptActivityParameterDirection.OUTPUT)
+ .withSize(2076493341))),
+ new ScriptActivityScriptBlock().withText("datal")
+ .withType("dataj")
+ .withParameters(
+ Arrays.asList(
+ new ScriptActivityParameter().withName("databbon")
+ .withType(ScriptActivityParameterType.GUID)
+ .withValue("datafseykprgpqnesu")
+ .withDirection(ScriptActivityParameterDirection.OUTPUT)
+ .withSize(1419451177),
+ new ScriptActivityParameter().withName("datazadpwhldx")
+ .withType(ScriptActivityParameterType.INT32)
+ .withValue("datatt")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(995318961),
+ new ScriptActivityParameter().withName("datagzssg")
+ .withType(ScriptActivityParameterType.BOOLEAN)
+ .withValue("datavqetvcxabzwehvs")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(905453692),
+ new ScriptActivityParameter().withName("datahiaomldtkqoajp")
+ .withType(ScriptActivityParameterType.INT32)
+ .withValue("dataafhz")
+ .withDirection(ScriptActivityParameterDirection.OUTPUT)
+ .withSize(1911604908))),
+ new ScriptActivityScriptBlock().withText("dataozqusdznnhh")
+ .withType("datadfyusiupdmbh")
+ .withParameters(Arrays.asList(
+ new ScriptActivityParameter().withName("datawgteroaenvjouz")
+ .withType(ScriptActivityParameterType.INT64)
+ .withValue("databraqzrbvogfm")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(1572339861),
+ new ScriptActivityParameter().withName("datanlqnklbwyqoyp")
+ .withType(ScriptActivityParameterType.INT32)
+ .withValue("dataajxmgxsp")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(779229082)))))
+ .withLogSettings(
+ new ScriptActivityTypePropertiesLogSettings()
+ .withLogDestination(ScriptActivityLogDestination.ACTIVITY_OUTPUT)
+ .withLogLocationSettings(new LogLocationSettings()
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("kwvjo")
+ .withParameters(mapOf("cloyvr", "dataaiydjgkdjmylhcjx", "bkigzvugwbc",
+ "datazepnlwuhtfabafk", "ixp", "dataabsqpttulhanjui", "sk", "datatfdujuoiien")))
+ .withPath("dataaqb")))
+ .withReturnMultistatementResult("datacnbnlpp");
model = BinaryData.fromObject(model).toObject(ScriptActivity.class);
- Assertions.assertEquals("n", model.name());
- Assertions.assertEquals("elxmulyal", model.description());
+ Assertions.assertEquals("zqeinnbu", model.name());
+ Assertions.assertEquals("vtykfxoss", model.description());
Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("fdyawetkrmq", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("enobfviscauudx", model.userProperties().get(0).name());
- Assertions.assertEquals("qlxwretsphetrq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1054322566, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals(ScriptActivityParameterType.STRING, model.scripts().get(0).parameters().get(0).type());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("l", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("rvpaumkzd", model.userProperties().get(0).name());
+ Assertions.assertEquals("bipfazsayrk", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(662631486, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(ScriptActivityParameterType.INT64, model.scripts().get(0).parameters().get(0).type());
Assertions.assertEquals(ScriptActivityParameterDirection.INPUT,
model.scripts().get(0).parameters().get(0).direction());
- Assertions.assertEquals(2133630125, model.scripts().get(0).parameters().get(0).size());
- Assertions.assertEquals(ScriptActivityLogDestination.EXTERNAL_STORE, model.logSettings().logDestination());
- Assertions.assertEquals("zeylthdrnzeidblr",
- model.logSettings().logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals(53251602, model.scripts().get(0).parameters().get(0).size());
+ Assertions.assertEquals(ScriptActivityLogDestination.ACTIVITY_OUTPUT, model.logSettings().logDestination());
+ Assertions.assertEquals("kwvjo", model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesLogSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesLogSettingsTests.java
index 250c9b646b13..670bebae64d2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesLogSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesLogSettingsTests.java
@@ -17,24 +17,27 @@ public final class ScriptActivityTypePropertiesLogSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScriptActivityTypePropertiesLogSettings model = BinaryData.fromString(
- "{\"logDestination\":\"ExternalStore\",\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"qwxsli\",\"parameters\":{\"rjwllg\":\"dataxwyfeqajtzquh\",\"jzycqiz\":\"datackoxk\"}},\"path\":\"datau\"}}")
+ "{\"logDestination\":\"ActivityOutput\",\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"deewjgj\",\"parameters\":{\"ozjfigitiswxcvwh\":\"dataazuned\",\"ixsvoob\":\"datatjjqz\",\"u\":\"datasrisfccf\"}},\"path\":\"dataihifrkyvutwmc\"}}")
.toObject(ScriptActivityTypePropertiesLogSettings.class);
- Assertions.assertEquals(ScriptActivityLogDestination.EXTERNAL_STORE, model.logDestination());
- Assertions.assertEquals("qwxsli", model.logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals(ScriptActivityLogDestination.ACTIVITY_OUTPUT, model.logDestination());
+ Assertions.assertEquals("deewjgj", model.logLocationSettings().linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
ScriptActivityTypePropertiesLogSettings model
= new ScriptActivityTypePropertiesLogSettings()
- .withLogDestination(ScriptActivityLogDestination.EXTERNAL_STORE)
- .withLogLocationSettings(new LogLocationSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qwxsli")
- .withParameters(mapOf("rjwllg", "dataxwyfeqajtzquh", "jzycqiz", "datackoxk")))
- .withPath("datau"));
+ .withLogDestination(ScriptActivityLogDestination.ACTIVITY_OUTPUT)
+ .withLogLocationSettings(
+ new LogLocationSettings()
+ .withLinkedServiceName(
+ new LinkedServiceReference().withReferenceName("deewjgj")
+ .withParameters(mapOf("ozjfigitiswxcvwh", "dataazuned", "ixsvoob", "datatjjqz", "u",
+ "datasrisfccf")))
+ .withPath("dataihifrkyvutwmc"));
model = BinaryData.fromObject(model).toObject(ScriptActivityTypePropertiesLogSettings.class);
- Assertions.assertEquals(ScriptActivityLogDestination.EXTERNAL_STORE, model.logDestination());
- Assertions.assertEquals("qwxsli", model.logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals(ScriptActivityLogDestination.ACTIVITY_OUTPUT, model.logDestination());
+ Assertions.assertEquals("deewjgj", model.logLocationSettings().linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesTests.java
index e4801ca937e5..9e940f1acdde 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ScriptActivityTypePropertiesTests.java
@@ -23,53 +23,97 @@ public final class ScriptActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ScriptActivityTypeProperties model = BinaryData.fromString(
- "{\"scriptBlockExecutionTimeout\":\"datadxmplxzrof\",\"scripts\":[{\"text\":\"databrt\",\"type\":\"datayjqur\",\"parameters\":[{\"name\":\"datazkpumzdatbo\",\"type\":\"Double\",\"value\":\"dataavphuperrpzcvgi\",\"direction\":\"Output\",\"size\":1216838662},{\"name\":\"datagccqefewof\",\"type\":\"Single\",\"value\":\"dataqkb\",\"direction\":\"Input\",\"size\":987205767},{\"name\":\"datatzxvfsrufjf\",\"type\":\"DateTime\",\"value\":\"datafbzjvzgyzenveiy\",\"direction\":\"Output\",\"size\":737775312}]}],\"logSettings\":{\"logDestination\":\"ActivityOutput\",\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"dumpmxofkbbch\",\"parameters\":{\"blkpteclfjaue\":\"datacskmrvgd\",\"cfgrtgnvlrm\":\"datazpp\"}},\"path\":\"dataz\"}}}")
+ "{\"scriptBlockExecutionTimeout\":\"datayspkyswyaejffv\",\"scripts\":[{\"text\":\"datahgqsjecccf\",\"type\":\"datacywcuhqfxfe\",\"parameters\":[{\"name\":\"dataurermnyph\",\"type\":\"Int16\",\"value\":\"datast\",\"direction\":\"Input\",\"size\":106174222}]},{\"text\":\"datanvubszjyttgkps\",\"type\":\"datamtcczz\",\"parameters\":[{\"name\":\"datamgezkb\",\"type\":\"Double\",\"value\":\"datatlomeczdn\",\"direction\":\"Output\",\"size\":1235599878},{\"name\":\"dataefn\",\"type\":\"Boolean\",\"value\":\"datavbsbhdtiaqafalb\",\"direction\":\"InputOutput\",\"size\":581465328}]},{\"text\":\"datalvdh\",\"type\":\"datadvdbrrkvxm\",\"parameters\":[{\"name\":\"dataziwndnpojmgke\",\"type\":\"Int16\",\"value\":\"datahdsuwonj\",\"direction\":\"Input\",\"size\":1854528563},{\"name\":\"dataik\",\"type\":\"Decimal\",\"value\":\"dataehiegkpukvalcv\",\"direction\":\"InputOutput\",\"size\":391306202},{\"name\":\"datai\",\"type\":\"DateTime\",\"value\":\"dataio\",\"direction\":\"Input\",\"size\":401236974}]},{\"text\":\"datakmwzsmyakph\",\"type\":\"datasmkhkuk\",\"parameters\":[{\"name\":\"databsii\",\"type\":\"Boolean\",\"value\":\"databnqyswpnoghk\",\"direction\":\"InputOutput\",\"size\":406966962},{\"name\":\"dataduwttrvgzjfptpr\",\"type\":\"Int64\",\"value\":\"datazgyondzvtfk\",\"direction\":\"Output\",\"size\":971597158},{\"name\":\"dataiyjqbezvxebdhp\",\"type\":\"DateTime\",\"value\":\"dataqkylmfy\",\"direction\":\"InputOutput\",\"size\":1357722450},{\"name\":\"datawbkfcajtxzduqt\",\"type\":\"String\",\"value\":\"datagrfzaexewftqo\",\"direction\":\"Input\",\"size\":436489942}]}],\"logSettings\":{\"logDestination\":\"ExternalStore\",\"logLocationSettings\":{\"linkedServiceName\":{\"referenceName\":\"hmesk\",\"parameters\":{\"bdajc\":\"datap\",\"jryppvdhklcczg\":\"datarlnxjucoj\"}},\"path\":\"dataogzstc\"}},\"returnMultistatementResult\":\"databftafrbuvw\"}")
.toObject(ScriptActivityTypeProperties.class);
- Assertions.assertEquals(ScriptActivityParameterType.DOUBLE, model.scripts().get(0).parameters().get(0).type());
- Assertions.assertEquals(ScriptActivityParameterDirection.OUTPUT,
+ Assertions.assertEquals(ScriptActivityParameterType.INT16, model.scripts().get(0).parameters().get(0).type());
+ Assertions.assertEquals(ScriptActivityParameterDirection.INPUT,
model.scripts().get(0).parameters().get(0).direction());
- Assertions.assertEquals(1216838662, model.scripts().get(0).parameters().get(0).size());
- Assertions.assertEquals(ScriptActivityLogDestination.ACTIVITY_OUTPUT, model.logSettings().logDestination());
- Assertions.assertEquals("dumpmxofkbbch",
- model.logSettings().logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals(106174222, model.scripts().get(0).parameters().get(0).size());
+ Assertions.assertEquals(ScriptActivityLogDestination.EXTERNAL_STORE, model.logSettings().logDestination());
+ Assertions.assertEquals("hmesk", model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
ScriptActivityTypeProperties model
- = new ScriptActivityTypeProperties().withScriptBlockExecutionTimeout("datadxmplxzrof")
- .withScripts(Arrays.asList(new ScriptActivityScriptBlock().withText("databrt")
- .withType("datayjqur")
- .withParameters(Arrays.asList(
- new ScriptActivityParameter().withName("datazkpumzdatbo")
- .withType(ScriptActivityParameterType.DOUBLE)
- .withValue("dataavphuperrpzcvgi")
- .withDirection(ScriptActivityParameterDirection.OUTPUT)
- .withSize(1216838662),
- new ScriptActivityParameter().withName("datagccqefewof")
- .withType(ScriptActivityParameterType.SINGLE)
- .withValue("dataqkb")
- .withDirection(ScriptActivityParameterDirection.INPUT)
- .withSize(987205767),
- new ScriptActivityParameter().withName("datatzxvfsrufjf")
- .withType(ScriptActivityParameterType.DATE_TIME)
- .withValue("datafbzjvzgyzenveiy")
- .withDirection(ScriptActivityParameterDirection.OUTPUT)
- .withSize(737775312)))))
+ = new ScriptActivityTypeProperties().withScriptBlockExecutionTimeout("datayspkyswyaejffv")
+ .withScripts(
+ Arrays.asList(
+ new ScriptActivityScriptBlock().withText("datahgqsjecccf")
+ .withType("datacywcuhqfxfe")
+ .withParameters(Arrays.asList(new ScriptActivityParameter().withName("dataurermnyph")
+ .withType(ScriptActivityParameterType.INT16)
+ .withValue("datast")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(106174222))),
+ new ScriptActivityScriptBlock().withText("datanvubszjyttgkps")
+ .withType("datamtcczz")
+ .withParameters(Arrays.asList(
+ new ScriptActivityParameter().withName("datamgezkb")
+ .withType(ScriptActivityParameterType.DOUBLE)
+ .withValue("datatlomeczdn")
+ .withDirection(ScriptActivityParameterDirection.OUTPUT)
+ .withSize(1235599878),
+ new ScriptActivityParameter().withName("dataefn")
+ .withType(ScriptActivityParameterType.BOOLEAN)
+ .withValue("datavbsbhdtiaqafalb")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(581465328))),
+ new ScriptActivityScriptBlock().withText("datalvdh")
+ .withType("datadvdbrrkvxm")
+ .withParameters(Arrays.asList(
+ new ScriptActivityParameter().withName("dataziwndnpojmgke")
+ .withType(ScriptActivityParameterType.INT16)
+ .withValue("datahdsuwonj")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(1854528563),
+ new ScriptActivityParameter().withName("dataik")
+ .withType(ScriptActivityParameterType.DECIMAL)
+ .withValue("dataehiegkpukvalcv")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(391306202),
+ new ScriptActivityParameter().withName("datai")
+ .withType(ScriptActivityParameterType.DATE_TIME)
+ .withValue("dataio")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(401236974))),
+ new ScriptActivityScriptBlock().withText("datakmwzsmyakph")
+ .withType("datasmkhkuk")
+ .withParameters(Arrays.asList(
+ new ScriptActivityParameter().withName("databsii")
+ .withType(ScriptActivityParameterType.BOOLEAN)
+ .withValue("databnqyswpnoghk")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(406966962),
+ new ScriptActivityParameter().withName("dataduwttrvgzjfptpr")
+ .withType(ScriptActivityParameterType.INT64)
+ .withValue("datazgyondzvtfk")
+ .withDirection(ScriptActivityParameterDirection.OUTPUT)
+ .withSize(971597158),
+ new ScriptActivityParameter().withName("dataiyjqbezvxebdhp")
+ .withType(ScriptActivityParameterType.DATE_TIME)
+ .withValue("dataqkylmfy")
+ .withDirection(ScriptActivityParameterDirection.INPUT_OUTPUT)
+ .withSize(1357722450),
+ new ScriptActivityParameter().withName("datawbkfcajtxzduqt")
+ .withType(ScriptActivityParameterType.STRING)
+ .withValue("datagrfzaexewftqo")
+ .withDirection(ScriptActivityParameterDirection.INPUT)
+ .withSize(436489942)))))
.withLogSettings(new ScriptActivityTypePropertiesLogSettings()
- .withLogDestination(ScriptActivityLogDestination.ACTIVITY_OUTPUT)
+ .withLogDestination(ScriptActivityLogDestination.EXTERNAL_STORE)
.withLogLocationSettings(new LogLocationSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("dumpmxofkbbch")
- .withParameters(mapOf("blkpteclfjaue", "datacskmrvgd", "cfgrtgnvlrm", "datazpp")))
- .withPath("dataz")));
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hmesk")
+ .withParameters(mapOf("bdajc", "datap", "jryppvdhklcczg", "datarlnxjucoj")))
+ .withPath("dataogzstc")))
+ .withReturnMultistatementResult("databftafrbuvw");
model = BinaryData.fromObject(model).toObject(ScriptActivityTypeProperties.class);
- Assertions.assertEquals(ScriptActivityParameterType.DOUBLE, model.scripts().get(0).parameters().get(0).type());
- Assertions.assertEquals(ScriptActivityParameterDirection.OUTPUT,
+ Assertions.assertEquals(ScriptActivityParameterType.INT16, model.scripts().get(0).parameters().get(0).type());
+ Assertions.assertEquals(ScriptActivityParameterDirection.INPUT,
model.scripts().get(0).parameters().get(0).direction());
- Assertions.assertEquals(1216838662, model.scripts().get(0).parameters().get(0).size());
- Assertions.assertEquals(ScriptActivityLogDestination.ACTIVITY_OUTPUT, model.logSettings().logDestination());
- Assertions.assertEquals("dumpmxofkbbch",
- model.logSettings().logLocationSettings().linkedServiceName().referenceName());
+ Assertions.assertEquals(106174222, model.scripts().get(0).parameters().get(0).size());
+ Assertions.assertEquals(ScriptActivityLogDestination.EXTERNAL_STORE, model.logSettings().logDestination());
+ Assertions.assertEquals("hmesk", model.logSettings().logLocationSettings().linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SecureInputOutputPolicyTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SecureInputOutputPolicyTests.java
index 7dcae072388b..ee3cc9e105d2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SecureInputOutputPolicyTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SecureInputOutputPolicyTests.java
@@ -11,17 +11,17 @@
public final class SecureInputOutputPolicyTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SecureInputOutputPolicy model = BinaryData.fromString("{\"secureInput\":false,\"secureOutput\":true}")
+ SecureInputOutputPolicy model = BinaryData.fromString("{\"secureInput\":true,\"secureOutput\":true}")
.toObject(SecureInputOutputPolicy.class);
- Assertions.assertEquals(false, model.secureInput());
+ Assertions.assertEquals(true, model.secureInput());
Assertions.assertEquals(true, model.secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SecureInputOutputPolicy model = new SecureInputOutputPolicy().withSecureInput(false).withSecureOutput(true);
+ SecureInputOutputPolicy model = new SecureInputOutputPolicy().withSecureInput(true).withSecureOutput(true);
model = BinaryData.fromObject(model).toObject(SecureInputOutputPolicy.class);
- Assertions.assertEquals(false, model.secureInput());
+ Assertions.assertEquals(true, model.secureInput());
Assertions.assertEquals(true, model.secureOutput());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfDependencyTumblingWindowTriggerReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfDependencyTumblingWindowTriggerReferenceTests.java
index 2ec31b346346..09f258a210e2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfDependencyTumblingWindowTriggerReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfDependencyTumblingWindowTriggerReferenceTests.java
@@ -12,18 +12,18 @@ public final class SelfDependencyTumblingWindowTriggerReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SelfDependencyTumblingWindowTriggerReference model = BinaryData.fromString(
- "{\"type\":\"SelfDependencyTumblingWindowTriggerReference\",\"offset\":\"wucpdzbntyo\",\"size\":\"npuyhqaylsmehl\"}")
+ "{\"type\":\"SelfDependencyTumblingWindowTriggerReference\",\"offset\":\"jveujgsxrsxb\",\"size\":\"mv\"}")
.toObject(SelfDependencyTumblingWindowTriggerReference.class);
- Assertions.assertEquals("wucpdzbntyo", model.offset());
- Assertions.assertEquals("npuyhqaylsmehl", model.size());
+ Assertions.assertEquals("jveujgsxrsxb", model.offset());
+ Assertions.assertEquals("mv", model.size());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SelfDependencyTumblingWindowTriggerReference model
- = new SelfDependencyTumblingWindowTriggerReference().withOffset("wucpdzbntyo").withSize("npuyhqaylsmehl");
+ = new SelfDependencyTumblingWindowTriggerReference().withOffset("jveujgsxrsxb").withSize("mv");
model = BinaryData.fromObject(model).toObject(SelfDependencyTumblingWindowTriggerReference.class);
- Assertions.assertEquals("wucpdzbntyo", model.offset());
- Assertions.assertEquals("npuyhqaylsmehl", model.size());
+ Assertions.assertEquals("jveujgsxrsxb", model.offset());
+ Assertions.assertEquals("mv", model.size());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTests.java
index e74d9a831841..ec8e465a5ecd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTests.java
@@ -18,7 +18,7 @@ public final class SelfHostedIntegrationRuntimeStatusTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SelfHostedIntegrationRuntimeStatus model = BinaryData.fromString(
- "{\"type\":\"SelfHosted\",\"typeProperties\":{\"createTime\":\"2021-10-19T21:10:31Z\",\"taskQueueId\":\"fsssmy\",\"internalChannelEncryption\":\"NotEncrypted\",\"version\":\"rhbsdgktlu\",\"nodes\":[{\"nodeName\":\"gpqc\",\"machineName\":\"nobqysbeespq\",\"hostServiceUri\":\"vae\",\"status\":\"InitializeFailed\",\"capabilities\":{\"ricv\":\"fzsaut\",\"zunhyyqxckdl\":\"ofenin\",\"ncbesfvijnu\":\"jpisrdnow\"},\"versionStatus\":\"fiiytqxewjsyu\",\"version\":\"zlghkvoxdp\",\"registerTime\":\"2021-05-27T22:13:23Z\",\"lastConnectTime\":\"2021-12-03T10:30:18Z\",\"expiryTime\":\"2021-08-14T12:28:51Z\",\"lastStartTime\":\"2021-09-05T12:26:50Z\",\"lastStopTime\":\"2021-10-25T10:44:43Z\",\"lastUpdateResult\":\"Succeed\",\"lastStartUpdateTime\":\"2021-10-18T15:20:22Z\",\"lastEndUpdateTime\":\"2021-02-18T11:20:26Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":1098696529,\"maxConcurrentJobs\":1386786245,\"\":{\"pwxnblzrmi\":\"datanpwdwdmuvyakrb\"}},{\"nodeName\":\"othyfjbp\",\"machineName\":\"dhfrvsi\",\"hostServiceUri\":\"wgnpcjnia\",\"status\":\"NeedRegistration\",\"capabilities\":{\"uuogdkpnm\":\"jjioq\",\"xqucnbgibkls\":\"rfuqjdeb\",\"evbfvxmtsmgkret\":\"wdkouzyvi\",\"ceulbyz\":\"ny\"},\"versionStatus\":\"xsygaoymyckd\",\"version\":\"brxbmljrjyfjl\",\"registerTime\":\"2021-08-29T14:58:42Z\",\"lastConnectTime\":\"2021-10-18T07:17:24Z\",\"expiryTime\":\"2021-03-14T00:44:48Z\",\"lastStartTime\":\"2021-04-09T05:29:06Z\",\"lastStopTime\":\"2021-08-10T05:40:55Z\",\"lastUpdateResult\":\"Succeed\",\"lastStartUpdateTime\":\"2021-08-17T06:45Z\",\"lastEndUpdateTime\":\"2021-02-26T23:11:52Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":1855197747,\"maxConcurrentJobs\":582722035,\"\":{\"csotwqtkpdcdefqo\":\"datai\",\"nddaxaogsk\":\"datarmgm\",\"fjcvmkkbpgdiwd\":\"datacmmmbipysehyybo\",\"cehzrtrgpd\":\"datayhdtiembrwqwvc\"}},{\"nodeName\":\"t\",\"machineName\":\"hyfwjfqktuzr\",\"hostServiceUri\":\"pecsdk\",\"status\":\"Online\",\"capabilities\":{\"hjlugcupcyfrhoo\":\"vttqjntvhnjp\",\"vuxyeeafdxsuwly\":\"v\",\"hj\":\"xzhgbspdx\"},\"versionStatus\":\"xkzxqomzdfa\",\"version\":\"qve\",\"registerTime\":\"2021-04-19T01:11:47Z\",\"lastConnectTime\":\"2021-01-05T03:49:30Z\",\"expiryTime\":\"2021-12-04T14:35:50Z\",\"lastStartTime\":\"2021-09-24T04:45:33Z\",\"lastStopTime\":\"2021-08-21T16:12:51Z\",\"lastUpdateResult\":\"Succeed\",\"lastStartUpdateTime\":\"2021-01-08T15:40:51Z\",\"lastEndUpdateTime\":\"2021-07-23T22:08:33Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":1876720469,\"maxConcurrentJobs\":988799296,\"\":{\"wqlbxmynslcvyn\":\"dataxapew\",\"czroddc\":\"datavwttts\",\"k\":\"dataqimodnbjmj\",\"fja\":\"databucmzkqt\"}}],\"scheduledUpdateDate\":\"2021-05-09T21:24:46Z\",\"updateDelayOffset\":\"vcebgo\",\"localTimeZoneOffset\":\"fyplavbvs\",\"capabilities\":{\"teikf\":\"dsoqwexiebnz\",\"etqj\":\"jqdfadgywyla\"},\"serviceUrls\":[\"ys\"],\"autoUpdate\":\"Off\",\"versionStatus\":\"tpbtkogfggylyzol\",\"links\":[{\"name\":\"gseqjte\",\"subscriptionId\":\"xirmgiswr\",\"dataFactoryName\":\"bpvsobamtarir\",\"dataFactoryLocation\":\"dgvqoflzukegougx\",\"createTime\":\"2021-07-17T07:20:10Z\"},{\"name\":\"mzqsx\",\"subscriptionId\":\"mnxrxkulytivviyq\",\"dataFactoryName\":\"bxxyfozbgodywxj\",\"dataFactoryLocation\":\"frxvlusedpnkz\",\"createTime\":\"2021-10-16T13:48:56Z\"},{\"name\":\"xtm\",\"subscriptionId\":\"ycv\",\"dataFactoryName\":\"axjdqvvyje\",\"dataFactoryLocation\":\"vnfjng\",\"createTime\":\"2021-11-29T07:11:20Z\"}],\"pushedVersion\":\"dvhbgtuhwhxunwe\",\"latestVersion\":\"p\",\"autoUpdateETA\":\"2021-02-07T17:03:10Z\",\"selfContainedInteractiveAuthoringEnabled\":false},\"dataFactoryName\":\"gzrxxdusebkcfet\",\"state\":\"Limited\",\"\":{\"uiqr\":\"dataerma\",\"ftubqwxvs\":\"datan\"}}")
+ "{\"type\":\"SelfHosted\",\"typeProperties\":{\"createTime\":\"2021-02-01T10:07:26Z\",\"taskQueueId\":\"mmmbipyse\",\"internalChannelEncryption\":\"NotSet\",\"version\":\"obfjcvmkkbpgdiw\",\"nodes\":[{\"nodeName\":\"d\",\"machineName\":\"embr\",\"hostServiceUri\":\"wvcwcehzrtrgp\",\"status\":\"Upgrading\",\"capabilities\":{\"pecsdk\":\"xhyfwjfqktuzrl\",\"njpbhjlugcupcyfr\":\"qfzbvttqjntv\"},\"versionStatus\":\"oyvmvuxyeeafd\",\"version\":\"uwlynxzhgbs\",\"registerTime\":\"2021-08-10T16:26:43Z\",\"lastConnectTime\":\"2021-08-16T00:47:39Z\",\"expiryTime\":\"2021-02-20T20:50:01Z\",\"lastStartTime\":\"2021-07-04T02:32:58Z\",\"lastStopTime\":\"2021-11-02T23:47:18Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-01-16T08:04:52Z\",\"lastEndUpdateTime\":\"2021-12-04T02:47:07Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":935204104,\"maxConcurrentJobs\":1895404533,\"\":{\"modwhqu\":\"datadzwnkbjqp\",\"wz\":\"datasochtuxap\",\"bx\":\"dataq\"}},{\"nodeName\":\"nslcvynavwttts\",\"machineName\":\"z\",\"hostServiceUri\":\"ddcaqimodnbjmjxk\",\"status\":\"Limited\",\"capabilities\":{\"cebgodjfyplav\":\"zkqtkfjackta\",\"ecedsoqwexie\":\"v\",\"ywylav\":\"nzoteikffjqdfad\"},\"versionStatus\":\"q\",\"version\":\"ohystdgjtpbtkogf\",\"registerTime\":\"2021-05-15T17:11Z\",\"lastConnectTime\":\"2021-08-02T13:45:25Z\",\"expiryTime\":\"2021-03-08T03:38:01Z\",\"lastStartTime\":\"2021-10-07T06:11:05Z\",\"lastStopTime\":\"2021-08-26T01:52:01Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-08-17T14:21:54Z\",\"lastEndUpdateTime\":\"2021-01-20T01:43:38Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":1045454101,\"maxConcurrentJobs\":1577135191,\"\":{\"jy\":\"datagisw\"}},{\"nodeName\":\"vsobamtarirdzdgv\",\"machineName\":\"flz\",\"hostServiceUri\":\"e\",\"status\":\"Online\",\"capabilities\":{\"qsxblmnxrxkul\":\"pypbm\",\"godywxjikfrx\":\"tivviyqonbxxyfoz\",\"nkzimqa\":\"lused\"},\"versionStatus\":\"mvmycvjpaxjdqvvy\",\"version\":\"hyvnfjngoq\",\"registerTime\":\"2021-03-19T08:40:35Z\",\"lastConnectTime\":\"2021-09-10T09:59:19Z\",\"expiryTime\":\"2021-01-22T15:49:35Z\",\"lastStartTime\":\"2021-07-01T02:38:11Z\",\"lastStopTime\":\"2021-09-04T10:10:29Z\",\"lastUpdateResult\":\"None\",\"lastStartUpdateTime\":\"2021-10-21T18:54:20Z\",\"lastEndUpdateTime\":\"2021-07-31T23:50:38Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":2080228934,\"maxConcurrentJobs\":1608026781,\"\":{\"x\":\"datazgz\",\"nterma\":\"datadusebkcfetxp\"}},{\"nodeName\":\"iqrsnmftubqwxv\",\"machineName\":\"rbi\",\"hostServiceUri\":\"jlgrwjb\",\"status\":\"Limited\",\"capabilities\":{\"eyx\":\"bocsitsxhvsgzpwq\",\"ttampqep\":\"kctyq\",\"ub\":\"ft\"},\"versionStatus\":\"zoepeqlhbtysyiz\",\"version\":\"lctpqnofkwh\",\"registerTime\":\"2021-01-16T19:09:50Z\",\"lastConnectTime\":\"2021-03-05T01:40:28Z\",\"expiryTime\":\"2021-07-01T01:46:58Z\",\"lastStartTime\":\"2021-05-10T10:09:31Z\",\"lastStopTime\":\"2021-06-01T06:29:17Z\",\"lastUpdateResult\":\"None\",\"lastStartUpdateTime\":\"2020-12-20T02:18:07Z\",\"lastEndUpdateTime\":\"2021-06-28T10:21:14Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":585694832,\"maxConcurrentJobs\":1011648765,\"\":{\"wbmacvemmriyz\":\"datajsmvsiyqmlmwjwsm\",\"xplcsinb\":\"datavque\"}}],\"scheduledUpdateDate\":\"2021-04-08T05:40:51Z\",\"updateDelayOffset\":\"xxhcynnmvaiz\",\"localTimeZoneOffset\":\"wqqpwcidsjqcqyz\",\"capabilities\":{\"likalbcyuwahw\":\"fdlgpryy\"},\"serviceUrls\":[\"vaidzcephn\",\"nuhgy\",\"zkhi\"],\"autoUpdate\":\"Off\",\"versionStatus\":\"pekiprjbp\",\"links\":[{\"name\":\"pairpwjmcgi\",\"subscriptionId\":\"ywpejtvqopugrs\",\"dataFactoryName\":\"giuztqefzypul\",\"dataFactoryLocation\":\"mcbcen\",\"createTime\":\"2021-09-30T16:48:42Z\"},{\"name\":\"uepikwc\",\"subscriptionId\":\"asgukq\",\"dataFactoryName\":\"iy\",\"dataFactoryLocation\":\"fvkiw\",\"createTime\":\"2021-02-23T21:58:36Z\"},{\"name\":\"mytcctirgyut\",\"subscriptionId\":\"nzhdm\",\"dataFactoryName\":\"vjbryb\",\"dataFactoryLocation\":\"rkh\",\"createTime\":\"2021-07-10T18:03:20Z\"},{\"name\":\"ud\",\"subscriptionId\":\"m\",\"dataFactoryName\":\"h\",\"dataFactoryLocation\":\"jjhq\",\"createTime\":\"2021-11-04T10:24:23Z\"}],\"pushedVersion\":\"jfpxoygnmjniqwu\",\"latestVersion\":\"yxfknj\",\"autoUpdateETA\":\"2021-01-16T14:28:10Z\",\"selfContainedInteractiveAuthoringEnabled\":true},\"dataFactoryName\":\"vravntvklkwqi\",\"state\":\"Limited\",\"\":{\"tdmewwlkr\":\"dataymketot\",\"pgqqdhtctx\":\"dataz\",\"zjohdhczh\":\"dataregykjmpad\",\"xgjqqbactffxd\":\"dataxitydljgrpqua\"}}")
.toObject(SelfHostedIntegrationRuntimeStatus.class);
}
@@ -26,47 +26,58 @@ public void testDeserialize() throws Exception {
public void testSerialize() throws Exception {
SelfHostedIntegrationRuntimeStatus model = new SelfHostedIntegrationRuntimeStatus()
.withNodes(Arrays.asList(
- new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf("nodeName", "gpqc",
- "lastStartUpdateTime", "2021-10-18T15:20:22Z", "lastConnectTime", "2021-12-03T10:30:18Z",
+ new SelfHostedIntegrationRuntimeNodeInner()
+ .withAdditionalProperties(mapOf("nodeName", "d", "lastStartUpdateTime", "2021-01-16T08:04:52Z",
+ "lastConnectTime", "2021-08-16T00:47:39Z", "capabilities",
+ JacksonAdapter.createDefaultSerializerAdapter()
+ .deserialize("{\"pecsdk\":\"xhyfwjfqktuzrl\",\"njpbhjlugcupcyfr\":\"qfzbvttqjntv\"}",
+ Object.class, SerializerEncoding.JSON),
+ "hostServiceUri", "wvcwcehzrtrgp", "registerTime", "2021-08-10T16:26:43Z", "maxConcurrentJobs",
+ 1895404533, "lastStopTime", "2021-11-02T23:47:18Z", "version", "uwlynxzhgbs", "machineName",
+ "embr", "versionStatus", "oyvmvuxyeeafd", "concurrentJobsLimit", 935204104, "lastEndUpdateTime",
+ "2021-12-04T02:47:07Z", "expiryTime", "2021-02-20T20:50:01Z", "lastStartTime",
+ "2021-07-04T02:32:58Z", "lastUpdateResult", "Fail", "isActiveDispatcher", true, "status",
+ "Upgrading")),
+ new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf("nodeName", "nslcvynavwttts",
+ "lastStartUpdateTime", "2021-08-17T14:21:54Z", "lastConnectTime", "2021-08-02T13:45:25Z",
"capabilities",
JacksonAdapter.createDefaultSerializerAdapter()
.deserialize(
- "{\"ricv\":\"fzsaut\",\"zunhyyqxckdl\":\"ofenin\",\"ncbesfvijnu\":\"jpisrdnow\"}",
+ "{\"cebgodjfyplav\":\"zkqtkfjackta\",\"ecedsoqwexie\":\"v\",\"ywylav\":\"nzoteikffjqdfad\"}",
Object.class, SerializerEncoding.JSON),
- "hostServiceUri", "vae", "registerTime", "2021-05-27T22:13:23Z", "maxConcurrentJobs", 1386786245,
- "lastStopTime", "2021-10-25T10:44:43Z", "version", "zlghkvoxdp", "machineName", "nobqysbeespq",
- "versionStatus", "fiiytqxewjsyu", "concurrentJobsLimit", 1098696529, "lastEndUpdateTime",
- "2021-02-18T11:20:26Z", "expiryTime", "2021-08-14T12:28:51Z", "lastStartTime",
- "2021-09-05T12:26:50Z", "lastUpdateResult", "Succeed", "isActiveDispatcher", true, "status",
- "InitializeFailed")),
- new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf("nodeName", "othyfjbp",
- "lastStartUpdateTime", "2021-08-17T06:45Z", "lastConnectTime", "2021-10-18T07:17:24Z",
- "capabilities",
+ "hostServiceUri", "ddcaqimodnbjmjxk", "registerTime", "2021-05-15T17:11Z", "maxConcurrentJobs",
+ 1577135191, "lastStopTime", "2021-08-26T01:52:01Z", "version", "ohystdgjtpbtkogf", "machineName",
+ "z", "versionStatus", "q", "concurrentJobsLimit", 1045454101, "lastEndUpdateTime",
+ "2021-01-20T01:43:38Z", "expiryTime", "2021-03-08T03:38:01Z", "lastStartTime",
+ "2021-10-07T06:11:05Z", "lastUpdateResult", "Fail", "isActiveDispatcher", false, "status",
+ "Limited")),
+ new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf("nodeName",
+ "vsobamtarirdzdgv", "lastStartUpdateTime", "2021-10-21T18:54:20Z", "lastConnectTime",
+ "2021-09-10T09:59:19Z", "capabilities",
JacksonAdapter.createDefaultSerializerAdapter()
.deserialize(
- "{\"uuogdkpnm\":\"jjioq\",\"xqucnbgibkls\":\"rfuqjdeb\",\"evbfvxmtsmgkret\":\"wdkouzyvi\",\"ceulbyz\":\"ny\"}",
+ "{\"qsxblmnxrxkul\":\"pypbm\",\"godywxjikfrx\":\"tivviyqonbxxyfoz\",\"nkzimqa\":\"lused\"}",
Object.class, SerializerEncoding.JSON),
- "hostServiceUri", "wgnpcjnia", "registerTime", "2021-08-29T14:58:42Z", "maxConcurrentJobs",
- 582722035, "lastStopTime", "2021-08-10T05:40:55Z", "version", "brxbmljrjyfjl", "machineName",
- "dhfrvsi", "versionStatus", "xsygaoymyckd", "concurrentJobsLimit", 1855197747, "lastEndUpdateTime",
- "2021-02-26T23:11:52Z", "expiryTime", "2021-03-14T00:44:48Z", "lastStartTime",
- "2021-04-09T05:29:06Z", "lastUpdateResult", "Succeed", "isActiveDispatcher", true, "status",
- "NeedRegistration")),
+ "hostServiceUri", "e", "registerTime", "2021-03-19T08:40:35Z", "maxConcurrentJobs", 1608026781,
+ "lastStopTime", "2021-09-04T10:10:29Z", "version", "hyvnfjngoq", "machineName", "flz",
+ "versionStatus", "mvmycvjpaxjdqvvy", "concurrentJobsLimit", 2080228934, "lastEndUpdateTime",
+ "2021-07-31T23:50:38Z", "expiryTime", "2021-01-22T15:49:35Z", "lastStartTime",
+ "2021-07-01T02:38:11Z", "lastUpdateResult", "None", "isActiveDispatcher", true, "status",
+ "Online")),
new SelfHostedIntegrationRuntimeNodeInner()
- .withAdditionalProperties(mapOf("nodeName", "t", "lastStartUpdateTime", "2021-01-08T15:40:51Z",
- "lastConnectTime", "2021-01-05T03:49:30Z", "capabilities",
+ .withAdditionalProperties(mapOf("nodeName", "iqrsnmftubqwxv", "lastStartUpdateTime",
+ "2020-12-20T02:18:07Z", "lastConnectTime", "2021-03-05T01:40:28Z", "capabilities",
JacksonAdapter.createDefaultSerializerAdapter()
- .deserialize(
- "{\"hjlugcupcyfrhoo\":\"vttqjntvhnjp\",\"vuxyeeafdxsuwly\":\"v\",\"hj\":\"xzhgbspdx\"}",
+ .deserialize("{\"eyx\":\"bocsitsxhvsgzpwq\",\"ttampqep\":\"kctyq\",\"ub\":\"ft\"}",
Object.class, SerializerEncoding.JSON),
- "hostServiceUri", "pecsdk", "registerTime", "2021-04-19T01:11:47Z", "maxConcurrentJobs",
- 988799296, "lastStopTime", "2021-08-21T16:12:51Z", "version", "qve", "machineName",
- "hyfwjfqktuzr", "versionStatus", "xkzxqomzdfa", "concurrentJobsLimit", 1876720469,
- "lastEndUpdateTime", "2021-07-23T22:08:33Z", "expiryTime", "2021-12-04T14:35:50Z",
- "lastStartTime", "2021-09-24T04:45:33Z", "lastUpdateResult", "Succeed", "isActiveDispatcher",
- true, "status", "Online"))))
+ "hostServiceUri", "jlgrwjb", "registerTime", "2021-01-16T19:09:50Z", "maxConcurrentJobs",
+ 1011648765, "lastStopTime", "2021-06-01T06:29:17Z", "version", "lctpqnofkwh", "machineName",
+ "rbi", "versionStatus", "zoepeqlhbtysyiz", "concurrentJobsLimit", 585694832,
+ "lastEndUpdateTime", "2021-06-28T10:21:14Z", "expiryTime", "2021-07-01T01:46:58Z",
+ "lastStartTime", "2021-05-10T10:09:31Z", "lastUpdateResult", "None", "isActiveDispatcher",
+ false, "status", "Limited"))))
.withLinks(Arrays.asList(new LinkedIntegrationRuntime(), new LinkedIntegrationRuntime(),
- new LinkedIntegrationRuntime()));
+ new LinkedIntegrationRuntime(), new LinkedIntegrationRuntime()));
model = BinaryData.fromObject(model).toObject(SelfHostedIntegrationRuntimeStatus.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTypePropertiesTests.java
index e228bf5588cb..f9a6bccd044b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SelfHostedIntegrationRuntimeStatusTypePropertiesTests.java
@@ -18,60 +18,63 @@ public final class SelfHostedIntegrationRuntimeStatusTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SelfHostedIntegrationRuntimeStatusTypeProperties model = BinaryData.fromString(
- "{\"createTime\":\"2021-10-10T22:16:57Z\",\"taskQueueId\":\"yzjlgrwjbsycukb\",\"internalChannelEncryption\":\"NotEncrypted\",\"version\":\"t\",\"nodes\":[{\"nodeName\":\"sgzpwqieyxjkc\",\"machineName\":\"qst\",\"hostServiceUri\":\"m\",\"status\":\"Online\",\"capabilities\":{\"ub\":\"ft\",\"oepeqlhbtysy\":\"l\"},\"versionStatus\":\"e\",\"version\":\"ctpqnofkw\",\"registerTime\":\"2021-09-17T16:10:32Z\",\"lastConnectTime\":\"2021-08-28T05:34:45Z\",\"expiryTime\":\"2021-03-08T07:52:39Z\",\"lastStartTime\":\"2021-06-27T09:54:45Z\",\"lastStopTime\":\"2021-01-24T22:20:59Z\",\"lastUpdateResult\":\"Succeed\",\"lastStartUpdateTime\":\"2021-07-23T15:09:30Z\",\"lastEndUpdateTime\":\"2021-05-25T11:30:54Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":708652737,\"maxConcurrentJobs\":1122817965,\"\":{\"yqmlmwjwsmnwbm\":\"datajjsmvs\",\"vque\":\"datacvemmriyz\",\"lolxxhcyn\":\"dataxplcsinb\"}},{\"nodeName\":\"vaizvkwqqpwcid\",\"machineName\":\"qcqyzmrtfdl\",\"hostServiceUri\":\"ryyjlikalbcyuwah\",\"status\":\"InitializeFailed\",\"capabilities\":{\"nuhgy\":\"aidzcephn\",\"mrwpe\":\"zkhi\",\"rjbpertjpair\":\"i\"},\"versionStatus\":\"jmcgiw\",\"version\":\"wpejtvqo\",\"registerTime\":\"2021-06-02T02:29:28Z\",\"lastConnectTime\":\"2021-06-30T15:48:53Z\",\"expiryTime\":\"2021-09-12T05:48Z\",\"lastStartTime\":\"2021-10-16T20:30:06Z\",\"lastStopTime\":\"2021-06-21T01:55:54Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-07-23T05:04:48Z\",\"lastEndUpdateTime\":\"2021-09-28T18:44:07Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":528922339,\"maxConcurrentJobs\":1433779054,\"\":{\"ikwcx\":\"datacendidhue\",\"kiynbf\":\"dataasgukq\",\"irgyutexnzh\":\"datakiwmqnwmytcc\"}},{\"nodeName\":\"cgvjbrybfar\",\"machineName\":\"koqcudnwmoyhdpjj\",\"hostServiceUri\":\"nzcbjfpxoygnm\",\"status\":\"Online\",\"capabilities\":{\"knjqsstnw\":\"uqxyx\"},\"versionStatus\":\"avntvklkw\",\"version\":\"snlpaymketotk\",\"registerTime\":\"2020-12-30T06:28:35Z\",\"lastConnectTime\":\"2021-05-12T15:08:36Z\",\"expiryTime\":\"2021-10-24T23:18:34Z\",\"lastStartTime\":\"2021-11-22T06:56:32Z\",\"lastStopTime\":\"2021-05-25T11:08:26Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-05-10T19:11:58Z\",\"lastEndUpdateTime\":\"2021-03-27T21:03:38Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":382099748,\"maxConcurrentJobs\":675074110,\"\":{\"adbzjohd\":\"datagykjm\",\"ljgrpquafxgjqq\":\"dataczhdxity\",\"wafapctgljo\":\"dataactffxdbisihu\",\"ufqiqddjynpgomz\":\"dataizqqihvb\"}},{\"nodeName\":\"jpajlf\",\"machineName\":\"vrljlhejcccp\",\"hostServiceUri\":\"nwit\",\"status\":\"Upgrading\",\"capabilities\":{\"skplqftqcxqm\":\"vptvitghzqwvkpa\"},\"versionStatus\":\"udcykgul\",\"version\":\"lfw\",\"registerTime\":\"2021-03-27T14:44:34Z\",\"lastConnectTime\":\"2021-09-19T18:27:34Z\",\"expiryTime\":\"2021-06-08T02:55:02Z\",\"lastStartTime\":\"2020-12-31T20:59:05Z\",\"lastStopTime\":\"2021-06-20T22:53:30Z\",\"lastUpdateResult\":\"Succeed\",\"lastStartUpdateTime\":\"2021-07-04T05:20:19Z\",\"lastEndUpdateTime\":\"2021-05-04T15:23:13Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":1012333610,\"maxConcurrentJobs\":409889565,\"\":{\"rppoy\":\"datasdlraduhgwaxz\"}}],\"scheduledUpdateDate\":\"2021-06-29T22:25:46Z\",\"updateDelayOffset\":\"ibes\",\"localTimeZoneOffset\":\"opbksrib\",\"capabilities\":{\"gwsfrlyvzl\":\"morikczerqtiq\",\"doqgrucw\":\"jydg\",\"rru\":\"cyjudhgwjqeglym\"},\"serviceUrls\":[\"piyxkmqmgexqcilf\",\"ulgnnyxwdpm\",\"e\"],\"autoUpdate\":\"On\",\"versionStatus\":\"z\",\"links\":[{\"name\":\"mqrbbsnptmmvdpa\",\"subscriptionId\":\"jkb\",\"dataFactoryName\":\"uwhizcbqjxmhw\",\"dataFactoryLocation\":\"unpcskdlrf\",\"createTime\":\"2021-08-30T14:05:50Z\"},{\"name\":\"oltj\",\"subscriptionId\":\"u\",\"dataFactoryName\":\"jltyhddzeykudj\",\"dataFactoryLocation\":\"imyehplmqyo\",\"createTime\":\"2021-03-28T03:32:28Z\"},{\"name\":\"axznqqkq\",\"subscriptionId\":\"dglseuqkr\",\"dataFactoryName\":\"yakr\",\"dataFactoryLocation\":\"bnwgokrllb\",\"createTime\":\"2021-03-21T00:24:12Z\"}],\"pushedVersion\":\"nvxouh\",\"latestVersion\":\"ftp\",\"autoUpdateETA\":\"2021-10-01T09:43:03Z\",\"selfContainedInteractiveAuthoringEnabled\":true}")
+ "{\"createTime\":\"2021-04-29T07:34:42Z\",\"taskQueueId\":\"humwafap\",\"internalChannelEncryption\":\"NotEncrypted\",\"version\":\"jopizqqihvbku\",\"nodes\":[{\"nodeName\":\"ddj\",\"machineName\":\"pgom\",\"hostServiceUri\":\"kjpajl\",\"status\":\"NeedRegistration\",\"capabilities\":{\"tafjjev\":\"ljlhejcccpxbnw\",\"skplqftqcxqm\":\"tvitghzqwvkpa\",\"rm\":\"sudcykgulellf\",\"oubxlpkdsnbqoyms\":\"uxyqbm\"},\"versionStatus\":\"ra\",\"version\":\"hgw\",\"registerTime\":\"2021-06-11T23:29:53Z\",\"lastConnectTime\":\"2021-08-07T06:11:26Z\",\"expiryTime\":\"2021-11-11T04:40:15Z\",\"lastStartTime\":\"2021-05-31T04:42:50Z\",\"lastStopTime\":\"2021-06-23T22:55:39Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-09-29T21:30:44Z\",\"lastEndUpdateTime\":\"2021-02-17T06:34:28Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":1913572156,\"maxConcurrentJobs\":1190968303,\"\":{\"qtiqxgwsfrlyvzl\":\"dataibmbtmorikcze\",\"doqgrucw\":\"datajydg\",\"rru\":\"datacyjudhgwjqeglym\"}},{\"nodeName\":\"qpiyxkmqmgex\",\"machineName\":\"ilfiulgnnyxw\",\"hostServiceUri\":\"mcewqvvzx\",\"status\":\"NeedRegistration\",\"capabilities\":{\"kbyjuwhizcbqjxm\":\"rbbsnptmmvdpavc\",\"wkoltjdauujjl\":\"wdtunpcskdlrfo\",\"ehplmqyoduksa\":\"yhddzeykudjzrim\",\"qkrbyyakrjgbnw\":\"znqqkqxkdglse\"},\"versionStatus\":\"krllbeca\",\"version\":\"vxouhdcftptfcj\",\"registerTime\":\"2021-01-25T11:05:39Z\",\"lastConnectTime\":\"2021-06-23T07:24:03Z\",\"expiryTime\":\"2021-08-23T20:16:45Z\",\"lastStartTime\":\"2021-01-19T05:08:58Z\",\"lastStopTime\":\"2021-03-31T22:15:51Z\",\"lastUpdateResult\":\"None\",\"lastStartUpdateTime\":\"2021-01-03T03:22:02Z\",\"lastEndUpdateTime\":\"2021-02-28T04:14:14Z\",\"isActiveDispatcher\":false,\"concurrentJobsLimit\":73571477,\"maxConcurrentJobs\":1351118080,\"\":{\"rtngiqcypmonfcor\":\"datahmqyufpfowweyls\",\"dtjfrponajzdj\":\"datanhfycigcbmay\",\"krbgvojcks\":\"datazbrwrfrmhouf\",\"gnzadqmvpehpn\":\"datarsnqunniklyxde\"}},{\"nodeName\":\"kyqhrpl\",\"machineName\":\"q\",\"hostServiceUri\":\"ojsrgc\",\"status\":\"Initializing\",\"capabilities\":{\"hhaq\":\"b\",\"ywdpuowl\":\"ytuecmgu\"},\"versionStatus\":\"xkr\",\"version\":\"tqzqnbseujcmtci\",\"registerTime\":\"2021-07-15T12:20:20Z\",\"lastConnectTime\":\"2021-11-07T15:09:17Z\",\"expiryTime\":\"2021-01-30T07:38:31Z\",\"lastStartTime\":\"2021-11-02T14:22:09Z\",\"lastStopTime\":\"2021-11-26T07:27:12Z\",\"lastUpdateResult\":\"Fail\",\"lastStartUpdateTime\":\"2021-03-03T15:52:27Z\",\"lastEndUpdateTime\":\"2020-12-25T01:01:32Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":350719333,\"maxConcurrentJobs\":1822892993,\"\":{\"wkjzvqpsymt\":\"datak\",\"nqhyefnak\":\"datapyjtrxxzwd\"}},{\"nodeName\":\"tpjksdlulytjxhxw\",\"machineName\":\"ttl\",\"hostServiceUri\":\"u\",\"status\":\"Limited\",\"capabilities\":{\"tqdapyds\":\"plugulynvpdv\",\"pj\":\"p\"},\"versionStatus\":\"ilbn\",\"version\":\"cqehy\",\"registerTime\":\"2021-06-16T02:56:55Z\",\"lastConnectTime\":\"2021-07-12T09:43:58Z\",\"expiryTime\":\"2021-09-06T00:06:37Z\",\"lastStartTime\":\"2021-01-10T13:31:11Z\",\"lastStopTime\":\"2021-03-27T19:04:08Z\",\"lastUpdateResult\":\"None\",\"lastStartUpdateTime\":\"2021-06-23T04:37:10Z\",\"lastEndUpdateTime\":\"2021-02-16T05:00:53Z\",\"isActiveDispatcher\":true,\"concurrentJobsLimit\":161997730,\"maxConcurrentJobs\":1564723464,\"\":{\"maxdwxrwq\":\"datae\"}}],\"scheduledUpdateDate\":\"2021-10-13T06:27:51Z\",\"updateDelayOffset\":\"sdta\",\"localTimeZoneOffset\":\"y\",\"capabilities\":{\"u\":\"gjhomywlypghhu\",\"b\":\"yfvgpqwgiqmbrisk\",\"lieegjnq\":\"ihtqfvyqmmczugu\",\"c\":\"hfjoxsehjscg\"},\"serviceUrls\":[\"ucftot\",\"dhjxdlmuhffjjq\",\"jyqmpmsknaxr\",\"ljw\"],\"autoUpdate\":\"Off\",\"versionStatus\":\"dpypb\",\"links\":[{\"name\":\"fxfpwmaj\",\"subscriptionId\":\"fijf\",\"dataFactoryName\":\"j\",\"dataFactoryLocation\":\"svhmsmrih\",\"createTime\":\"2021-09-22T10:36:59Z\"},{\"name\":\"wlbqntdder\",\"subscriptionId\":\"yiwuzpsvcmzs\",\"dataFactoryName\":\"tyyysqnwnl\",\"dataFactoryLocation\":\"zfjd\",\"createTime\":\"2021-11-13T07:00:46Z\"}],\"pushedVersion\":\"hsydph\",\"latestVersion\":\"zzetfg\",\"autoUpdateETA\":\"2021-08-29T00:05:45Z\",\"selfContainedInteractiveAuthoringEnabled\":false}")
.toObject(SelfHostedIntegrationRuntimeStatusTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SelfHostedIntegrationRuntimeStatusTypeProperties model = new SelfHostedIntegrationRuntimeStatusTypeProperties()
- .withNodes(Arrays.asList(
- new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf("nodeName", "sgzpwqieyxjkc",
- "lastStartUpdateTime", "2021-07-23T15:09:30Z", "lastConnectTime", "2021-08-28T05:34:45Z",
+ .withNodes(Arrays.asList(new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf(
+ "nodeName", "ddj", "lastStartUpdateTime", "2021-09-29T21:30:44Z", "lastConnectTime",
+ "2021-08-07T06:11:26Z", "capabilities",
+ JacksonAdapter.createDefaultSerializerAdapter()
+ .deserialize(
+ "{\"tafjjev\":\"ljlhejcccpxbnw\",\"skplqftqcxqm\":\"tvitghzqwvkpa\",\"rm\":\"sudcykgulellf\",\"oubxlpkdsnbqoyms\":\"uxyqbm\"}",
+ Object.class, SerializerEncoding.JSON),
+ "hostServiceUri", "kjpajl", "registerTime", "2021-06-11T23:29:53Z", "maxConcurrentJobs", 1190968303,
+ "lastStopTime", "2021-06-23T22:55:39Z", "version", "hgw", "machineName", "pgom", "versionStatus", "ra",
+ "concurrentJobsLimit", 1913572156, "lastEndUpdateTime", "2021-02-17T06:34:28Z", "expiryTime",
+ "2021-11-11T04:40:15Z", "lastStartTime", "2021-05-31T04:42:50Z", "lastUpdateResult", "Fail",
+ "isActiveDispatcher", true, "status", "NeedRegistration")),
+ new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf("nodeName", "qpiyxkmqmgex",
+ "lastStartUpdateTime", "2021-01-03T03:22:02Z", "lastConnectTime", "2021-06-23T07:24:03Z",
"capabilities",
JacksonAdapter.createDefaultSerializerAdapter()
- .deserialize("{\"ub\":\"ft\",\"oepeqlhbtysy\":\"l\"}", Object.class, SerializerEncoding.JSON),
- "hostServiceUri", "m", "registerTime", "2021-09-17T16:10:32Z", "maxConcurrentJobs", 1122817965,
- "lastStopTime", "2021-01-24T22:20:59Z", "version", "ctpqnofkw", "machineName", "qst",
- "versionStatus", "e", "concurrentJobsLimit", 708652737, "lastEndUpdateTime", "2021-05-25T11:30:54Z",
- "expiryTime", "2021-03-08T07:52:39Z", "lastStartTime", "2021-06-27T09:54:45Z", "lastUpdateResult",
- "Succeed", "isActiveDispatcher", false, "status", "Online")),
+ .deserialize(
+ "{\"kbyjuwhizcbqjxm\":\"rbbsnptmmvdpavc\",\"wkoltjdauujjl\":\"wdtunpcskdlrfo\",\"ehplmqyoduksa\":\"yhddzeykudjzrim\",\"qkrbyyakrjgbnw\":\"znqqkqxkdglse\"}",
+ Object.class, SerializerEncoding.JSON),
+ "hostServiceUri", "mcewqvvzx", "registerTime", "2021-01-25T11:05:39Z", "maxConcurrentJobs",
+ 1351118080, "lastStopTime", "2021-03-31T22:15:51Z", "version", "vxouhdcftptfcj", "machineName",
+ "ilfiulgnnyxw", "versionStatus", "krllbeca", "concurrentJobsLimit", 73571477, "lastEndUpdateTime",
+ "2021-02-28T04:14:14Z", "expiryTime", "2021-08-23T20:16:45Z", "lastStartTime",
+ "2021-01-19T05:08:58Z", "lastUpdateResult", "None", "isActiveDispatcher", false, "status",
+ "NeedRegistration")),
new SelfHostedIntegrationRuntimeNodeInner()
- .withAdditionalProperties(mapOf("nodeName", "vaizvkwqqpwcid", "lastStartUpdateTime",
- "2021-07-23T05:04:48Z", "lastConnectTime", "2021-06-30T15:48:53Z", "capabilities",
+ .withAdditionalProperties(mapOf("nodeName", "kyqhrpl", "lastStartUpdateTime",
+ "2021-03-03T15:52:27Z", "lastConnectTime", "2021-11-07T15:09:17Z", "capabilities",
JacksonAdapter.createDefaultSerializerAdapter()
- .deserialize("{\"nuhgy\":\"aidzcephn\",\"mrwpe\":\"zkhi\",\"rjbpertjpair\":\"i\"}",
- Object.class, SerializerEncoding.JSON),
- "hostServiceUri", "ryyjlikalbcyuwah", "registerTime", "2021-06-02T02:29:28Z",
- "maxConcurrentJobs", 1433779054, "lastStopTime", "2021-06-21T01:55:54Z", "version", "wpejtvqo",
- "machineName", "qcqyzmrtfdl", "versionStatus", "jmcgiw", "concurrentJobsLimit", 528922339,
- "lastEndUpdateTime", "2021-09-28T18:44:07Z", "expiryTime", "2021-09-12T05:48Z", "lastStartTime",
- "2021-10-16T20:30:06Z", "lastUpdateResult", "Fail", "isActiveDispatcher", false, "status",
- "InitializeFailed")),
+ .deserialize("{\"hhaq\":\"b\",\"ywdpuowl\":\"ytuecmgu\"}", Object.class,
+ SerializerEncoding.JSON),
+ "hostServiceUri", "ojsrgc", "registerTime", "2021-07-15T12:20:20Z", "maxConcurrentJobs",
+ 1822892993, "lastStopTime", "2021-11-26T07:27:12Z", "version", "tqzqnbseujcmtci", "machineName",
+ "q", "versionStatus", "xkr", "concurrentJobsLimit", 350719333, "lastEndUpdateTime",
+ "2020-12-25T01:01:32Z", "expiryTime", "2021-01-30T07:38:31Z", "lastStartTime",
+ "2021-11-02T14:22:09Z", "lastUpdateResult", "Fail", "isActiveDispatcher", true, "status",
+ "Initializing")),
new SelfHostedIntegrationRuntimeNodeInner()
- .withAdditionalProperties(mapOf("nodeName", "cgvjbrybfar", "lastStartUpdateTime",
- "2021-05-10T19:11:58Z", "lastConnectTime", "2021-05-12T15:08:36Z", "capabilities",
+ .withAdditionalProperties(mapOf("nodeName", "tpjksdlulytjxhxw", "lastStartUpdateTime",
+ "2021-06-23T04:37:10Z", "lastConnectTime", "2021-07-12T09:43:58Z", "capabilities",
JacksonAdapter.createDefaultSerializerAdapter()
- .deserialize("{\"knjqsstnw\":\"uqxyx\"}", Object.class, SerializerEncoding.JSON),
- "hostServiceUri", "nzcbjfpxoygnm", "registerTime", "2020-12-30T06:28:35Z", "maxConcurrentJobs",
- 675074110, "lastStopTime", "2021-05-25T11:08:26Z", "version", "snlpaymketotk", "machineName",
- "koqcudnwmoyhdpjj", "versionStatus", "avntvklkw", "concurrentJobsLimit", 382099748,
- "lastEndUpdateTime", "2021-03-27T21:03:38Z", "expiryTime", "2021-10-24T23:18:34Z",
- "lastStartTime", "2021-11-22T06:56:32Z", "lastUpdateResult", "Fail", "isActiveDispatcher",
- false, "status", "Online")),
- new SelfHostedIntegrationRuntimeNodeInner().withAdditionalProperties(mapOf("nodeName", "jpajlf",
- "lastStartUpdateTime", "2021-07-04T05:20:19Z", "lastConnectTime", "2021-09-19T18:27:34Z",
- "capabilities",
- JacksonAdapter.createDefaultSerializerAdapter()
- .deserialize("{\"skplqftqcxqm\":\"vptvitghzqwvkpa\"}", Object.class, SerializerEncoding.JSON),
- "hostServiceUri", "nwit", "registerTime", "2021-03-27T14:44:34Z", "maxConcurrentJobs", 409889565,
- "lastStopTime", "2021-06-20T22:53:30Z", "version", "lfw", "machineName", "vrljlhejcccp",
- "versionStatus", "udcykgul", "concurrentJobsLimit", 1012333610, "lastEndUpdateTime",
- "2021-05-04T15:23:13Z", "expiryTime", "2021-06-08T02:55:02Z", "lastStartTime",
- "2020-12-31T20:59:05Z", "lastUpdateResult", "Succeed", "isActiveDispatcher", false, "status",
- "Upgrading"))))
- .withLinks(Arrays.asList(new LinkedIntegrationRuntime(), new LinkedIntegrationRuntime(),
- new LinkedIntegrationRuntime()));
+ .deserialize("{\"tqdapyds\":\"plugulynvpdv\",\"pj\":\"p\"}", Object.class,
+ SerializerEncoding.JSON),
+ "hostServiceUri", "u", "registerTime", "2021-06-16T02:56:55Z", "maxConcurrentJobs", 1564723464,
+ "lastStopTime", "2021-03-27T19:04:08Z", "version", "cqehy", "machineName", "ttl",
+ "versionStatus", "ilbn", "concurrentJobsLimit", 161997730, "lastEndUpdateTime",
+ "2021-02-16T05:00:53Z", "expiryTime", "2021-09-06T00:06:37Z", "lastStartTime",
+ "2021-01-10T13:31:11Z", "lastUpdateResult", "None", "isActiveDispatcher", true, "status",
+ "Limited"))))
+ .withLinks(Arrays.asList(new LinkedIntegrationRuntime(), new LinkedIntegrationRuntime()));
model = BinaryData.fromObject(model).toObject(SelfHostedIntegrationRuntimeStatusTypeProperties.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowObjectDatasetTests.java
index 9e4143274d3e..38cf0b14aa2d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowObjectDatasetTests.java
@@ -19,31 +19,32 @@ public final class ServiceNowObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ServiceNowObjectDataset model = BinaryData.fromString(
- "{\"type\":\"ServiceNowObject\",\"typeProperties\":{\"tableName\":\"datazd\"},\"description\":\"bj\",\"structure\":\"datadsysx\",\"schema\":\"datauhvhnlse\",\"linkedServiceName\":{\"referenceName\":\"zcrrwnkkgdwqym\",\"parameters\":{\"eluvmsa\":\"dataqeaxd\",\"hvvzfznfgpbc\":\"datahviawgqrw\"}},\"parameters\":{\"djieask\":{\"type\":\"Object\",\"defaultValue\":\"datam\"}},\"annotations\":[\"dataclnfusrgnos\",\"datakhb\",\"datajphlyyuahvy\",\"dataikbvqzrurgbqaucp\"],\"folder\":{\"name\":\"jnohafwm\"},\"\":{\"tugpeametsdwxfa\":\"datajly\",\"fegs\":\"datatxc\",\"hooimazkmqfwbgd\":\"datavbghoucvkan\"}}")
+ "{\"type\":\"ServiceNowObject\",\"typeProperties\":{\"tableName\":\"datamfvybfmpotal\"},\"description\":\"figrxxtrco\",\"structure\":\"dataqe\",\"schema\":\"dataldmxxbjh\",\"linkedServiceName\":{\"referenceName\":\"pvamsxrwqlwdf\",\"parameters\":{\"bboffgxtae\":\"datarplzeqzv\",\"fcyatbxdwr\":\"dataxt\",\"fbpeigkflvovriq\":\"datayvtkmxvztshnu\"}},\"parameters\":{\"txur\":{\"type\":\"Float\",\"defaultValue\":\"datakqcgzygtdjhtbar\"}},\"annotations\":[\"datayyumhzpst\",\"datacqacvttyh\",\"databilnszyjbuw\"],\"folder\":{\"name\":\"sydsci\"},\"\":{\"l\":\"dataayioxpqgqs\",\"akqsjymcfv\":\"datalefeombodvdgf\",\"nbpkfnxrlncmlzvv\":\"datazceuyuqktck\",\"cjqzrevfwcba\":\"datamesfhqs\"}}")
.toObject(ServiceNowObjectDataset.class);
- Assertions.assertEquals("bj", model.description());
- Assertions.assertEquals("zcrrwnkkgdwqym", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("djieask").type());
- Assertions.assertEquals("jnohafwm", model.folder().name());
+ Assertions.assertEquals("figrxxtrco", model.description());
+ Assertions.assertEquals("pvamsxrwqlwdf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("txur").type());
+ Assertions.assertEquals("sydsci", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ServiceNowObjectDataset model = new ServiceNowObjectDataset().withDescription("bj")
- .withStructure("datadsysx")
- .withSchema("datauhvhnlse")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("zcrrwnkkgdwqym")
- .withParameters(mapOf("eluvmsa", "dataqeaxd", "hvvzfznfgpbc", "datahviawgqrw")))
- .withParameters(
- mapOf("djieask", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datam")))
- .withAnnotations(Arrays.asList("dataclnfusrgnos", "datakhb", "datajphlyyuahvy", "dataikbvqzrurgbqaucp"))
- .withFolder(new DatasetFolder().withName("jnohafwm"))
- .withTableName("datazd");
+ ServiceNowObjectDataset model = new ServiceNowObjectDataset().withDescription("figrxxtrco")
+ .withStructure("dataqe")
+ .withSchema("dataldmxxbjh")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("pvamsxrwqlwdf")
+ .withParameters(mapOf("bboffgxtae", "datarplzeqzv", "fcyatbxdwr", "dataxt", "fbpeigkflvovriq",
+ "datayvtkmxvztshnu")))
+ .withParameters(mapOf("txur",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datakqcgzygtdjhtbar")))
+ .withAnnotations(Arrays.asList("datayyumhzpst", "datacqacvttyh", "databilnszyjbuw"))
+ .withFolder(new DatasetFolder().withName("sydsci"))
+ .withTableName("datamfvybfmpotal");
model = BinaryData.fromObject(model).toObject(ServiceNowObjectDataset.class);
- Assertions.assertEquals("bj", model.description());
- Assertions.assertEquals("zcrrwnkkgdwqym", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("djieask").type());
- Assertions.assertEquals("jnohafwm", model.folder().name());
+ Assertions.assertEquals("figrxxtrco", model.description());
+ Assertions.assertEquals("pvamsxrwqlwdf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("txur").type());
+ Assertions.assertEquals("sydsci", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowSourceTests.java
index f9cfa6a91257..d1e19bf13a9e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowSourceTests.java
@@ -11,19 +11,19 @@ public final class ServiceNowSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ServiceNowSource model = BinaryData.fromString(
- "{\"type\":\"ServiceNowSource\",\"query\":\"datagw\",\"queryTimeout\":\"dataujshcsnk\",\"additionalColumns\":\"datagpqxqevt\",\"sourceRetryCount\":\"datavyy\",\"sourceRetryWait\":\"datakjirvjogsalvjl\",\"maxConcurrentConnections\":\"dataimua\",\"disableMetricsCollection\":\"datakympwquu\",\"\":{\"iqeftgunropdpuf\":\"dataofuzthszjyanhs\"}}")
+ "{\"type\":\"ServiceNowSource\",\"query\":\"databetzydtgpvnczf\",\"queryTimeout\":\"dataybjku\",\"additionalColumns\":\"dataajkyrhucbfkaqlp\",\"sourceRetryCount\":\"dataptero\",\"sourceRetryWait\":\"dataqaktao\",\"maxConcurrentConnections\":\"datagefobcqvzmyw\",\"disableMetricsCollection\":\"datayns\",\"\":{\"kklzabauvncln\":\"dataosqvojgol\",\"ikireetvjfizafd\":\"dataaoidjhoykgtyvrn\",\"csipfwlye\":\"datajhnuvndgrolgxa\",\"rzfppopwxxdgzhn\":\"dataajdpjmqteirrjjm\"}}")
.toObject(ServiceNowSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ServiceNowSource model = new ServiceNowSource().withSourceRetryCount("datavyy")
- .withSourceRetryWait("datakjirvjogsalvjl")
- .withMaxConcurrentConnections("dataimua")
- .withDisableMetricsCollection("datakympwquu")
- .withQueryTimeout("dataujshcsnk")
- .withAdditionalColumns("datagpqxqevt")
- .withQuery("datagw");
+ ServiceNowSource model = new ServiceNowSource().withSourceRetryCount("dataptero")
+ .withSourceRetryWait("dataqaktao")
+ .withMaxConcurrentConnections("datagefobcqvzmyw")
+ .withDisableMetricsCollection("datayns")
+ .withQueryTimeout("dataybjku")
+ .withAdditionalColumns("dataajkyrhucbfkaqlp")
+ .withQuery("databetzydtgpvnczf");
model = BinaryData.fromObject(model).toObject(ServiceNowSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2ObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2ObjectDatasetTests.java
index f6241c7a1a76..7f06cedd273a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2ObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2ObjectDatasetTests.java
@@ -19,31 +19,34 @@ public final class ServiceNowV2ObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ServiceNowV2ObjectDataset model = BinaryData.fromString(
- "{\"type\":\"ServiceNowV2Object\",\"typeProperties\":{\"tableName\":\"dataxux\"},\"description\":\"rutuh\",\"structure\":\"datamgxlssolqyp\",\"schema\":\"dataxlx\",\"linkedServiceName\":{\"referenceName\":\"hvrkqv\",\"parameters\":{\"dtuodocgq\":\"datadojcvzfcmxmjpjak\"}},\"parameters\":{\"qdsq\":{\"type\":\"Object\",\"defaultValue\":\"dataxp\"}},\"annotations\":[\"dataontqikd\"],\"folder\":{\"name\":\"xsq\"},\"\":{\"ihatajdt\":\"dataabrs\",\"xylsuioadohsjy\":\"datacvsyns\",\"nzkwlxqdsxipdnl\":\"dataehkxgfuzq\",\"wwgze\":\"datayitfz\"}}")
+ "{\"type\":\"ServiceNowV2Object\",\"typeProperties\":{\"tableName\":\"datavsveamseauuuvhx\"},\"description\":\"h\",\"structure\":\"datamufzuuyszhae\",\"schema\":\"datatyosdpxtsdy\",\"linkedServiceName\":{\"referenceName\":\"fgefvwgwp\",\"parameters\":{\"puhhzwrsjumlkjsv\":\"dataiavwmixaqg\"}},\"parameters\":{\"cjg\":{\"type\":\"Int\",\"defaultValue\":\"dataixalphkgminh\"},\"kpismmrmrj\":{\"type\":\"Bool\",\"defaultValue\":\"datajmsngmluyr\"},\"sabcylzz\":{\"type\":\"Bool\",\"defaultValue\":\"datahi\"}},\"annotations\":[\"dataumzenk\",\"datadrue\",\"dataxexawxoib\",\"datactjwfebqqq\"],\"folder\":{\"name\":\"sqaclczfrofy\"},\"\":{\"ptldddorzljhnxfk\":\"dataiaiidkewqwa\",\"vx\":\"datafngfpilloir\",\"rqmznwwtkuy\":\"databktuqnbcjk\"}}")
.toObject(ServiceNowV2ObjectDataset.class);
- Assertions.assertEquals("rutuh", model.description());
- Assertions.assertEquals("hvrkqv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("qdsq").type());
- Assertions.assertEquals("xsq", model.folder().name());
+ Assertions.assertEquals("h", model.description());
+ Assertions.assertEquals("fgefvwgwp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("cjg").type());
+ Assertions.assertEquals("sqaclczfrofy", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ServiceNowV2ObjectDataset model = new ServiceNowV2ObjectDataset().withDescription("rutuh")
- .withStructure("datamgxlssolqyp")
- .withSchema("dataxlx")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hvrkqv")
- .withParameters(mapOf("dtuodocgq", "datadojcvzfcmxmjpjak")))
- .withParameters(
- mapOf("qdsq", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataxp")))
- .withAnnotations(Arrays.asList("dataontqikd"))
- .withFolder(new DatasetFolder().withName("xsq"))
- .withTableName("dataxux");
+ ServiceNowV2ObjectDataset model = new ServiceNowV2ObjectDataset().withDescription("h")
+ .withStructure("datamufzuuyszhae")
+ .withSchema("datatyosdpxtsdy")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("fgefvwgwp")
+ .withParameters(mapOf("puhhzwrsjumlkjsv", "dataiavwmixaqg")))
+ .withParameters(mapOf("cjg",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataixalphkgminh"),
+ "kpismmrmrj",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datajmsngmluyr"),
+ "sabcylzz", new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datahi")))
+ .withAnnotations(Arrays.asList("dataumzenk", "datadrue", "dataxexawxoib", "datactjwfebqqq"))
+ .withFolder(new DatasetFolder().withName("sqaclczfrofy"))
+ .withTableName("datavsveamseauuuvhx");
model = BinaryData.fromObject(model).toObject(ServiceNowV2ObjectDataset.class);
- Assertions.assertEquals("rutuh", model.description());
- Assertions.assertEquals("hvrkqv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("qdsq").type());
- Assertions.assertEquals("xsq", model.folder().name());
+ Assertions.assertEquals("h", model.description());
+ Assertions.assertEquals("fgefvwgwp", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("cjg").type());
+ Assertions.assertEquals("sqaclczfrofy", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2SourceTests.java
index df36afcd0e7d..7763c90e03af 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ServiceNowV2SourceTests.java
@@ -15,54 +15,83 @@ public final class ServiceNowV2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ServiceNowV2Source model = BinaryData.fromString(
- "{\"type\":\"ServiceNowV2Source\",\"expression\":{\"type\":\"Constant\",\"value\":\"pjn\",\"operators\":[\"bxvouxcdenthgpw\",\"mevkckocexhlvf\"],\"operands\":[{\"type\":\"NAry\",\"value\":\"arohw\",\"operators\":[\"hzwsjqrmxpyzn\",\"amnkgmos\"],\"operands\":[{\"type\":\"Constant\",\"value\":\"dctpczzqusfugws\",\"operators\":[\"gij\",\"lyspk\",\"swyaejffvf\",\"khgqsjecccfyc\"],\"operands\":[{},{},{},{}]},{\"type\":\"Field\",\"value\":\"fx\",\"operators\":[\"f\",\"au\",\"ermnyphcoobs\",\"io\"],\"operands\":[{}]}]}]},\"queryTimeout\":\"datavubszjyttgkps\",\"additionalColumns\":\"datatcczzblalmgezk\",\"sourceRetryCount\":\"datairftlomec\",\"sourceRetryWait\":\"datangbgpxoefnb\",\"maxConcurrentConnections\":\"dataavbsbhdti\",\"disableMetricsCollection\":\"dataafalbkemodlvdhv\",\"\":{\"nd\":\"databrrkvxmeihrzi\",\"onjuwgvse\":\"datapojmgkeoqrxhdsu\"}}")
+ "{\"type\":\"ServiceNowV2Source\",\"expression\":{\"type\":\"NAry\",\"value\":\"aejbmt\",\"operators\":[\"eudfhcl\",\"sedxiigwxzwqjpu\",\"upishcvsjaaedsqf\"],\"operands\":[{\"type\":\"Field\",\"value\":\"w\",\"operators\":[\"ptfvoljnromhsias\"],\"operands\":[{\"type\":\"Binary\",\"value\":\"qckwccpmsyhrv\",\"operators\":[\"rgnxhoqfvuqim\",\"gkvfghcuiipnsz\",\"rmqtkxya\"],\"operands\":[{},{},{}]},{\"type\":\"Constant\",\"value\":\"xhxkm\",\"operators\":[\"ryoffglwmkmbxusn\"],\"operands\":[{},{},{},{}]},{\"type\":\"Field\",\"value\":\"sdbfbkqiceh\",\"operators\":[\"tffngrduco\",\"dzbh\"],\"operands\":[{},{},{}]}]},{\"type\":\"Constant\",\"value\":\"oxzhpbjhhuimgd\",\"operators\":[\"a\"],\"operands\":[{\"type\":\"Constant\",\"value\":\"avmd\",\"operators\":[\"l\",\"cvwewognpu\",\"paqj\"],\"operands\":[{},{},{}]},{\"type\":\"NAry\",\"value\":\"lritsxuxregfb\",\"operators\":[\"zpf\",\"mjgtjckf\",\"ljrlrkvhgnm\",\"xmmpuksvoimdg\"],\"operands\":[{}]},{\"type\":\"Constant\",\"value\":\"ieomiovbmwitnih\",\"operators\":[\"zd\",\"ggghwxpgftshcss\",\"ie\"],\"operands\":[{},{}]}]}]},\"pageSize\":\"datahfezzgnwxro\",\"queryTimeout\":\"dataoppzgvt\",\"additionalColumns\":\"dataobowh\",\"sourceRetryCount\":\"datassmlwadstl\",\"sourceRetryWait\":\"datagqmuthxoldmhyppt\",\"maxConcurrentConnections\":\"datap\",\"disableMetricsCollection\":\"datalwvezthgwqqt\",\"\":{\"bouwuajsitgpz\":\"datakyipzehitdq\"}}")
.toObject(ServiceNowV2Source.class);
- Assertions.assertEquals(ExpressionV2Type.CONSTANT, model.expression().type());
- Assertions.assertEquals("pjn", model.expression().value());
- Assertions.assertEquals("bxvouxcdenthgpw", model.expression().operators().get(0));
- Assertions.assertEquals(ExpressionV2Type.NARY, model.expression().operands().get(0).type());
- Assertions.assertEquals("arohw", model.expression().operands().get(0).value());
- Assertions.assertEquals("hzwsjqrmxpyzn", model.expression().operands().get(0).operators().get(0));
- Assertions.assertEquals(ExpressionV2Type.CONSTANT,
- model.expression().operands().get(0).operands().get(0).type());
- Assertions.assertEquals("dctpczzqusfugws", model.expression().operands().get(0).operands().get(0).value());
- Assertions.assertEquals("gij", model.expression().operands().get(0).operands().get(0).operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.NARY, model.expression().type());
+ Assertions.assertEquals("aejbmt", model.expression().value());
+ Assertions.assertEquals("eudfhcl", model.expression().operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.FIELD, model.expression().operands().get(0).type());
+ Assertions.assertEquals("w", model.expression().operands().get(0).value());
+ Assertions.assertEquals("ptfvoljnromhsias", model.expression().operands().get(0).operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.BINARY, model.expression().operands().get(0).operands().get(0).type());
+ Assertions.assertEquals("qckwccpmsyhrv", model.expression().operands().get(0).operands().get(0).value());
+ Assertions.assertEquals("rgnxhoqfvuqim",
+ model.expression().operands().get(0).operands().get(0).operators().get(0));
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ServiceNowV2Source model = new ServiceNowV2Source().withSourceRetryCount("datairftlomec")
- .withSourceRetryWait("datangbgpxoefnb")
- .withMaxConcurrentConnections("dataavbsbhdti")
- .withDisableMetricsCollection("dataafalbkemodlvdhv")
- .withQueryTimeout("datavubszjyttgkps")
- .withAdditionalColumns("datatcczzblalmgezk")
- .withExpression(new ExpressionV2().withType(ExpressionV2Type.CONSTANT)
- .withValue("pjn")
- .withOperators(Arrays.asList("bxvouxcdenthgpw", "mevkckocexhlvf"))
- .withOperands(Arrays.asList(new ExpressionV2().withType(ExpressionV2Type.NARY)
- .withValue("arohw")
- .withOperators(Arrays.asList("hzwsjqrmxpyzn", "amnkgmos"))
- .withOperands(Arrays.asList(
- new ExpressionV2().withType(ExpressionV2Type.CONSTANT)
- .withValue("dctpczzqusfugws")
- .withOperators(Arrays.asList("gij", "lyspk", "swyaejffvf", "khgqsjecccfyc"))
- .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(), new ExpressionV2(),
- new ExpressionV2())),
- new ExpressionV2().withType(ExpressionV2Type.FIELD)
- .withValue("fx")
- .withOperators(Arrays.asList("f", "au", "ermnyphcoobs", "io"))
- .withOperands(Arrays.asList(new ExpressionV2())))))));
+ ServiceNowV2Source model
+ = new ServiceNowV2Source().withSourceRetryCount("datassmlwadstl")
+ .withSourceRetryWait("datagqmuthxoldmhyppt")
+ .withMaxConcurrentConnections("datap")
+ .withDisableMetricsCollection("datalwvezthgwqqt")
+ .withQueryTimeout("dataoppzgvt")
+ .withAdditionalColumns("dataobowh")
+ .withExpression(
+ new ExpressionV2().withType(ExpressionV2Type.NARY)
+ .withValue("aejbmt")
+ .withOperators(Arrays.asList("eudfhcl", "sedxiigwxzwqjpu", "upishcvsjaaedsqf"))
+ .withOperands(
+ Arrays.asList(
+ new ExpressionV2().withType(ExpressionV2Type.FIELD)
+ .withValue("w")
+ .withOperators(Arrays.asList("ptfvoljnromhsias"))
+ .withOperands(Arrays.asList(
+ new ExpressionV2().withType(ExpressionV2Type.BINARY)
+ .withValue("qckwccpmsyhrv")
+ .withOperators(Arrays.asList("rgnxhoqfvuqim", "gkvfghcuiipnsz", "rmqtkxya"))
+ .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(),
+ new ExpressionV2())),
+ new ExpressionV2().withType(ExpressionV2Type.CONSTANT)
+ .withValue("xhxkm")
+ .withOperators(Arrays.asList("ryoffglwmkmbxusn"))
+ .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(),
+ new ExpressionV2(), new ExpressionV2())),
+ new ExpressionV2().withType(ExpressionV2Type.FIELD)
+ .withValue("sdbfbkqiceh")
+ .withOperators(Arrays.asList("tffngrduco", "dzbh"))
+ .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(),
+ new ExpressionV2())))),
+ new ExpressionV2().withType(ExpressionV2Type.CONSTANT)
+ .withValue("oxzhpbjhhuimgd")
+ .withOperators(Arrays.asList("a"))
+ .withOperands(Arrays.asList(
+ new ExpressionV2().withType(ExpressionV2Type.CONSTANT)
+ .withValue("avmd")
+ .withOperators(Arrays.asList("l", "cvwewognpu", "paqj"))
+ .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2(),
+ new ExpressionV2())),
+ new ExpressionV2().withType(ExpressionV2Type.NARY)
+ .withValue("lritsxuxregfb")
+ .withOperators(
+ Arrays.asList("zpf", "mjgtjckf", "ljrlrkvhgnm", "xmmpuksvoimdg"))
+ .withOperands(Arrays.asList(new ExpressionV2())),
+ new ExpressionV2().withType(ExpressionV2Type.CONSTANT)
+ .withValue("ieomiovbmwitnih")
+ .withOperators(Arrays.asList("zd", "ggghwxpgftshcss", "ie"))
+ .withOperands(Arrays.asList(new ExpressionV2(), new ExpressionV2())))))))
+ .withPageSize("datahfezzgnwxro");
model = BinaryData.fromObject(model).toObject(ServiceNowV2Source.class);
- Assertions.assertEquals(ExpressionV2Type.CONSTANT, model.expression().type());
- Assertions.assertEquals("pjn", model.expression().value());
- Assertions.assertEquals("bxvouxcdenthgpw", model.expression().operators().get(0));
- Assertions.assertEquals(ExpressionV2Type.NARY, model.expression().operands().get(0).type());
- Assertions.assertEquals("arohw", model.expression().operands().get(0).value());
- Assertions.assertEquals("hzwsjqrmxpyzn", model.expression().operands().get(0).operators().get(0));
- Assertions.assertEquals(ExpressionV2Type.CONSTANT,
- model.expression().operands().get(0).operands().get(0).type());
- Assertions.assertEquals("dctpczzqusfugws", model.expression().operands().get(0).operands().get(0).value());
- Assertions.assertEquals("gij", model.expression().operands().get(0).operands().get(0).operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.NARY, model.expression().type());
+ Assertions.assertEquals("aejbmt", model.expression().value());
+ Assertions.assertEquals("eudfhcl", model.expression().operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.FIELD, model.expression().operands().get(0).type());
+ Assertions.assertEquals("w", model.expression().operands().get(0).value());
+ Assertions.assertEquals("ptfvoljnromhsias", model.expression().operands().get(0).operators().get(0));
+ Assertions.assertEquals(ExpressionV2Type.BINARY, model.expression().operands().get(0).operands().get(0).type());
+ Assertions.assertEquals("qckwccpmsyhrv", model.expression().operands().get(0).operands().get(0).value());
+ Assertions.assertEquals("rgnxhoqfvuqim",
+ model.expression().operands().get(0).operands().get(0).operators().get(0));
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTests.java
index 4f553f7c8a84..1e6eb51b1f17 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTests.java
@@ -21,58 +21,55 @@ public final class SetVariableActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SetVariableActivity model = BinaryData.fromString(
- "{\"type\":\"SetVariable\",\"typeProperties\":{\"variableName\":\"lxlxlezzym\",\"value\":\"datazoiud\",\"setSystemVariable\":false},\"policy\":{\"secureInput\":false,\"secureOutput\":false},\"name\":\"xajiaycgxwacuudn\",\"description\":\"tsjafvzds\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"m\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"bsgzewyfh\":\"datavbnmzjwh\",\"lzqmwmwoggbxias\":\"dataz\",\"cnpfl\":\"dataiz\",\"pixuj\":\"dataedwhvhlzp\"}},{\"activity\":\"y\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Failed\",\"Failed\"],\"\":{\"bbnvctbtm\":\"datad\",\"lrvklyp\":\"dataanmpt\",\"soxykrmalen\":\"datauqyaisdiwokgv\"}},{\"activity\":\"bvahj\",\"dependencyConditions\":[\"Succeeded\",\"Completed\"],\"\":{\"jopsgedsyykueif\":\"dataebg\"}}],\"userProperties\":[{\"name\":\"ntlf\",\"value\":\"dataiq\"},{\"name\":\"vazffzhbh\",\"value\":\"datalgwlrdgp\"},{\"name\":\"dbimehdxcy\",\"value\":\"datayfhwkbhapfnyo\"}],\"\":{\"zunbcvfzc\":\"dataebehjrmfejeihnhw\",\"gudobutkq\":\"datayirngfujvxafrqq\"}}")
+ "{\"type\":\"SetVariable\",\"typeProperties\":{\"variableName\":\"adjllhzl\",\"value\":\"datavr\",\"setSystemVariable\":true},\"policy\":{\"secureInput\":true,\"secureOutput\":true},\"name\":\"vomxtosdbvudo\",\"description\":\"oheebzewbif\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"dhd\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Completed\",\"Failed\"],\"\":{\"fhmuaoouu\":\"datawrhkjmp\",\"hlggobjcfb\":\"datahfdggsrzol\",\"phzdkikjyhaqkglu\":\"datagelfkhmgsphoc\"}},{\"activity\":\"myqitsar\",\"dependencyConditions\":[\"Failed\"],\"\":{\"yryy\":\"datammjwmldgrwglmmca\"}}],\"userProperties\":[{\"name\":\"venmvhbgpgvlii\",\"value\":\"dataueltcoiszqf\"},{\"name\":\"biyvowyyvsbjpy\",\"value\":\"datalzxjiruq\"},{\"name\":\"rshtwdgoqxfbsci\",\"value\":\"dataizrorupduwqovlq\"}],\"\":{\"kovubfugdgpmtzqp\":\"dataehagorbspotq\",\"vetuqi\":\"datavochmeximhmi\"}}")
.toObject(SetVariableActivity.class);
- Assertions.assertEquals("xajiaycgxwacuudn", model.name());
- Assertions.assertEquals("tsjafvzds", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("m", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("ntlf", model.userProperties().get(0).name());
- Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("lxlxlezzym", model.variableName());
- Assertions.assertEquals(false, model.setSystemVariable());
+ Assertions.assertEquals("vomxtosdbvudo", model.name());
+ Assertions.assertEquals("oheebzewbif", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("dhd", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("venmvhbgpgvlii", model.userProperties().get(0).name());
+ Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("adjllhzl", model.variableName());
+ Assertions.assertEquals(true, model.setSystemVariable());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SetVariableActivity model = new SetVariableActivity().withName("xajiaycgxwacuudn")
- .withDescription("tsjafvzds")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ SetVariableActivity model = new SetVariableActivity().withName("vomxtosdbvudo")
+ .withDescription("oheebzewbif")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("m")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("dhd")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("y")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED,
- DependencyCondition.FAILED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("bvahj")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("myqitsar")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("ntlf").withValue("dataiq"),
- new UserProperty().withName("vazffzhbh").withValue("datalgwlrdgp"),
- new UserProperty().withName("dbimehdxcy").withValue("datayfhwkbhapfnyo")))
- .withPolicy(new SecureInputOutputPolicy().withSecureInput(false).withSecureOutput(false))
- .withVariableName("lxlxlezzym")
- .withValue("datazoiud")
- .withSetSystemVariable(false);
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("venmvhbgpgvlii").withValue("dataueltcoiszqf"),
+ new UserProperty().withName("biyvowyyvsbjpy").withValue("datalzxjiruq"),
+ new UserProperty().withName("rshtwdgoqxfbsci").withValue("dataizrorupduwqovlq")))
+ .withPolicy(new SecureInputOutputPolicy().withSecureInput(true).withSecureOutput(true))
+ .withVariableName("adjllhzl")
+ .withValue("datavr")
+ .withSetSystemVariable(true);
model = BinaryData.fromObject(model).toObject(SetVariableActivity.class);
- Assertions.assertEquals("xajiaycgxwacuudn", model.name());
- Assertions.assertEquals("tsjafvzds", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
- Assertions.assertEquals("m", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("ntlf", model.userProperties().get(0).name());
- Assertions.assertEquals(false, model.policy().secureInput());
- Assertions.assertEquals(false, model.policy().secureOutput());
- Assertions.assertEquals("lxlxlezzym", model.variableName());
- Assertions.assertEquals(false, model.setSystemVariable());
+ Assertions.assertEquals("vomxtosdbvudo", model.name());
+ Assertions.assertEquals("oheebzewbif", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
+ Assertions.assertEquals("dhd", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("venmvhbgpgvlii", model.userProperties().get(0).name());
+ Assertions.assertEquals(true, model.policy().secureInput());
+ Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals("adjllhzl", model.variableName());
+ Assertions.assertEquals(true, model.setSystemVariable());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTypePropertiesTests.java
index dc847d264454..6eb586203ba0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SetVariableActivityTypePropertiesTests.java
@@ -12,19 +12,20 @@ public final class SetVariableActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SetVariableActivityTypeProperties model = BinaryData
- .fromString("{\"variableName\":\"sxxc\",\"value\":\"datagraikiuxvd\",\"setSystemVariable\":false}")
+ .fromString("{\"variableName\":\"jamihnrulgypna\",\"value\":\"datajsdwnanuqn\",\"setSystemVariable\":true}")
.toObject(SetVariableActivityTypeProperties.class);
- Assertions.assertEquals("sxxc", model.variableName());
- Assertions.assertEquals(false, model.setSystemVariable());
+ Assertions.assertEquals("jamihnrulgypna", model.variableName());
+ Assertions.assertEquals(true, model.setSystemVariable());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SetVariableActivityTypeProperties model = new SetVariableActivityTypeProperties().withVariableName("sxxc")
- .withValue("datagraikiuxvd")
- .withSetSystemVariable(false);
+ SetVariableActivityTypeProperties model
+ = new SetVariableActivityTypeProperties().withVariableName("jamihnrulgypna")
+ .withValue("datajsdwnanuqn")
+ .withSetSystemVariable(true);
model = BinaryData.fromObject(model).toObject(SetVariableActivityTypeProperties.class);
- Assertions.assertEquals("sxxc", model.variableName());
- Assertions.assertEquals(false, model.setSystemVariable());
+ Assertions.assertEquals("jamihnrulgypna", model.variableName());
+ Assertions.assertEquals(true, model.setSystemVariable());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpReadSettingsTests.java
index 50a757e426a4..3a4996c118f9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpReadSettingsTests.java
@@ -11,24 +11,24 @@ public final class SftpReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SftpReadSettings model = BinaryData.fromString(
- "{\"type\":\"SftpReadSettings\",\"recursive\":\"dataekbpqghxdpg\",\"wildcardFolderPath\":\"datafimlyx\",\"wildcardFileName\":\"dataixjudbiac\",\"enablePartitionDiscovery\":\"dataoucmfuvuslvbujwp\",\"partitionRootPath\":\"dataijpyyvecruhqymwd\",\"fileListPath\":\"datahkt\",\"deleteFilesAfterCompletion\":\"dataljkh\",\"modifiedDatetimeStart\":\"datagtpgxkk\",\"modifiedDatetimeEnd\":\"datapxwlvth\",\"disableChunking\":\"dataa\",\"maxConcurrentConnections\":\"dataaxoswqw\",\"disableMetricsCollection\":\"datalrzlgk\",\"\":{\"erxfe\":\"datadk\"}}")
+ "{\"type\":\"SftpReadSettings\",\"recursive\":\"datab\",\"wildcardFolderPath\":\"datavkm\",\"wildcardFileName\":\"datajz\",\"enablePartitionDiscovery\":\"datakyvybljqgirpi\",\"partitionRootPath\":\"dataqrmxcu\",\"fileListPath\":\"datarkgg\",\"deleteFilesAfterCompletion\":\"dataqanrkhcdjfsvfbj\",\"modifiedDatetimeStart\":\"dataadwrbrntvhppykrl\",\"modifiedDatetimeEnd\":\"dataalsvxpola\",\"disableChunking\":\"datarjmsabnmu\",\"maxConcurrentConnections\":\"datathyxryv\",\"disableMetricsCollection\":\"datazhsigddgbcnqv\",\"\":{\"lemzrw\":\"databffcvtij\",\"kmkwddgyqeni\":\"datagvgogczgcm\",\"rtcbvifcrnxst\":\"datarznam\"}}")
.toObject(SftpReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SftpReadSettings model = new SftpReadSettings().withMaxConcurrentConnections("dataaxoswqw")
- .withDisableMetricsCollection("datalrzlgk")
- .withRecursive("dataekbpqghxdpg")
- .withWildcardFolderPath("datafimlyx")
- .withWildcardFileName("dataixjudbiac")
- .withEnablePartitionDiscovery("dataoucmfuvuslvbujwp")
- .withPartitionRootPath("dataijpyyvecruhqymwd")
- .withFileListPath("datahkt")
- .withDeleteFilesAfterCompletion("dataljkh")
- .withModifiedDatetimeStart("datagtpgxkk")
- .withModifiedDatetimeEnd("datapxwlvth")
- .withDisableChunking("dataa");
+ SftpReadSettings model = new SftpReadSettings().withMaxConcurrentConnections("datathyxryv")
+ .withDisableMetricsCollection("datazhsigddgbcnqv")
+ .withRecursive("datab")
+ .withWildcardFolderPath("datavkm")
+ .withWildcardFileName("datajz")
+ .withEnablePartitionDiscovery("datakyvybljqgirpi")
+ .withPartitionRootPath("dataqrmxcu")
+ .withFileListPath("datarkgg")
+ .withDeleteFilesAfterCompletion("dataqanrkhcdjfsvfbj")
+ .withModifiedDatetimeStart("dataadwrbrntvhppykrl")
+ .withModifiedDatetimeEnd("dataalsvxpola")
+ .withDisableChunking("datarjmsabnmu");
model = BinaryData.fromObject(model).toObject(SftpReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpWriteSettingsTests.java
index e72c05152bc9..a8c82963181c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SftpWriteSettingsTests.java
@@ -13,20 +13,19 @@ public final class SftpWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SftpWriteSettings model = BinaryData.fromString(
- "{\"type\":\"SftpWriteSettings\",\"operationTimeout\":\"dataqmwpmrlgjjqs\",\"useTempFileRename\":\"datap\",\"maxConcurrentConnections\":\"dataamvrejkvcimq\",\"disableMetricsCollection\":\"datad\",\"copyBehavior\":\"datahhwtgcgefayc\",\"metadata\":[{\"name\":\"datat\",\"value\":\"datanxoziotxnpov\"},{\"name\":\"dataxl\",\"value\":\"datamsgdisupnxth\"},{\"name\":\"datazdvokxuyhhrdi\",\"value\":\"databqeahgsibldxyaq\"}],\"\":{\"kgnrya\":\"dataznzaxzfhhhgy\"}}")
+ "{\"type\":\"SftpWriteSettings\",\"operationTimeout\":\"datadzlyogzba\",\"useTempFileRename\":\"datackakikkkajmnvbi\",\"maxConcurrentConnections\":\"datankrqd\",\"disableMetricsCollection\":\"dataoebgkx\",\"copyBehavior\":\"dataklqr\",\"metadata\":[{\"name\":\"datasaadaypxeqedftk\",\"value\":\"datamjnkttvzyvzi\"}],\"\":{\"fliqntnoegxo\":\"datasiidivbbrt\",\"dytwdaiexisa\":\"datapucl\",\"oukaffzzf\":\"dataygi\",\"orvigrxmptu\":\"dataivfiypfvwyzjsi\"}}")
.toObject(SftpWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SftpWriteSettings model = new SftpWriteSettings().withMaxConcurrentConnections("dataamvrejkvcimq")
- .withDisableMetricsCollection("datad")
- .withCopyBehavior("datahhwtgcgefayc")
- .withMetadata(Arrays.asList(new MetadataItem().withName("datat").withValue("datanxoziotxnpov"),
- new MetadataItem().withName("dataxl").withValue("datamsgdisupnxth"),
- new MetadataItem().withName("datazdvokxuyhhrdi").withValue("databqeahgsibldxyaq")))
- .withOperationTimeout("dataqmwpmrlgjjqs")
- .withUseTempFileRename("datap");
+ SftpWriteSettings model = new SftpWriteSettings().withMaxConcurrentConnections("datankrqd")
+ .withDisableMetricsCollection("dataoebgkx")
+ .withCopyBehavior("dataklqr")
+ .withMetadata(
+ Arrays.asList(new MetadataItem().withName("datasaadaypxeqedftk").withValue("datamjnkttvzyvzi")))
+ .withOperationTimeout("datadzlyogzba")
+ .withUseTempFileRename("datackakikkkajmnvbi");
model = BinaryData.fromObject(model).toObject(SftpWriteSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListDatasetTypePropertiesTests.java
index eee5f9847eac..a733376b908c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListDatasetTypePropertiesTests.java
@@ -10,14 +10,15 @@
public final class SharePointOnlineListDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SharePointOnlineListDatasetTypeProperties model = BinaryData.fromString("{\"listName\":\"datagba\"}")
- .toObject(SharePointOnlineListDatasetTypeProperties.class);
+ SharePointOnlineListDatasetTypeProperties model
+ = BinaryData.fromString("{\"listName\":\"datavihylrxsiyzsyium\"}")
+ .toObject(SharePointOnlineListDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SharePointOnlineListDatasetTypeProperties model
- = new SharePointOnlineListDatasetTypeProperties().withListName("datagba");
+ = new SharePointOnlineListDatasetTypeProperties().withListName("datavihylrxsiyzsyium");
model = BinaryData.fromObject(model).toObject(SharePointOnlineListDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListResourceDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListResourceDatasetTests.java
index 7a94c142e4cf..22dfbf38ef20 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListResourceDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListResourceDatasetTests.java
@@ -19,37 +19,38 @@ public final class SharePointOnlineListResourceDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SharePointOnlineListResourceDataset model = BinaryData.fromString(
- "{\"type\":\"SharePointOnlineListResource\",\"typeProperties\":{\"listName\":\"datad\"},\"description\":\"mipvlxtyw\",\"structure\":\"datahj\",\"schema\":\"datapllitx\",\"linkedServiceName\":{\"referenceName\":\"rgkwiyoy\",\"parameters\":{\"sizfuewlf\":\"dataivxcodwkwoytcach\",\"gne\":\"datafiikqcdnzsfiu\",\"mcrxlyzoaho\":\"datao\",\"rnlsyiaanistc\":\"dataufakrxjjwnbrmdwt\"}},\"parameters\":{\"fa\":{\"type\":\"Float\",\"defaultValue\":\"datalpphcstmrycpana\"},\"pxngzzxqbgq\":{\"type\":\"Object\",\"defaultValue\":\"datarin\"},\"vbdozwbskueaf\":{\"type\":\"SecureString\",\"defaultValue\":\"datazctbxzjkpifpu\"}},\"annotations\":[\"datambinpxmiwt\",\"dataqi\",\"datapvrd\"],\"folder\":{\"name\":\"d\"},\"\":{\"abux\":\"datax\"}}")
+ "{\"type\":\"SharePointOnlineListResource\",\"typeProperties\":{\"listName\":\"dataxtsa\"},\"description\":\"tcoojybolqox\",\"structure\":\"datatsl\",\"schema\":\"datavmlkwkzlinv\",\"linkedServiceName\":{\"referenceName\":\"mtykxszdekfxcsqm\",\"parameters\":{\"plrgcnbvmhvq\":\"datazktkdpczeo\"}},\"parameters\":{\"orfji\":{\"type\":\"String\",\"defaultValue\":\"dataxku\"},\"gavfyihu\":{\"type\":\"Float\",\"defaultValue\":\"datadawe\"},\"zgkooagrlwpame\":{\"type\":\"String\",\"defaultValue\":\"datapwnyfjcypazwiimd\"},\"atfamrna\":{\"type\":\"Float\",\"defaultValue\":\"datawqadewhuwxkyx\"}},\"annotations\":[\"datalxccprkiyf\",\"datazwhomydxgtuqbv\"],\"folder\":{\"name\":\"zihirqvvketyd\"},\"\":{\"aqgbb\":\"dataoktssgvqxerxrmhr\"}}")
.toObject(SharePointOnlineListResourceDataset.class);
- Assertions.assertEquals("mipvlxtyw", model.description());
- Assertions.assertEquals("rgkwiyoy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("fa").type());
- Assertions.assertEquals("d", model.folder().name());
+ Assertions.assertEquals("tcoojybolqox", model.description());
+ Assertions.assertEquals("mtykxszdekfxcsqm", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("orfji").type());
+ Assertions.assertEquals("zihirqvvketyd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SharePointOnlineListResourceDataset model = new SharePointOnlineListResourceDataset()
- .withDescription("mipvlxtyw")
- .withStructure("datahj")
- .withSchema("datapllitx")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rgkwiyoy")
- .withParameters(mapOf("sizfuewlf", "dataivxcodwkwoytcach", "gne", "datafiikqcdnzsfiu", "mcrxlyzoaho",
- "datao", "rnlsyiaanistc", "dataufakrxjjwnbrmdwt")))
- .withParameters(mapOf("fa",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datalpphcstmrycpana"),
- "pxngzzxqbgq", new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datarin"),
- "vbdozwbskueaf",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("datazctbxzjkpifpu")))
- .withAnnotations(Arrays.asList("datambinpxmiwt", "dataqi", "datapvrd"))
- .withFolder(new DatasetFolder().withName("d"))
- .withListName("datad");
+ .withDescription("tcoojybolqox")
+ .withStructure("datatsl")
+ .withSchema("datavmlkwkzlinv")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mtykxszdekfxcsqm")
+ .withParameters(mapOf("plrgcnbvmhvq", "datazktkdpczeo")))
+ .withParameters(
+ mapOf("orfji", new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataxku"),
+ "gavfyihu", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datadawe"),
+ "zgkooagrlwpame",
+ new ParameterSpecification().withType(ParameterType.STRING)
+ .withDefaultValue("datapwnyfjcypazwiimd"),
+ "atfamrna",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datawqadewhuwxkyx")))
+ .withAnnotations(Arrays.asList("datalxccprkiyf", "datazwhomydxgtuqbv"))
+ .withFolder(new DatasetFolder().withName("zihirqvvketyd"))
+ .withListName("dataxtsa");
model = BinaryData.fromObject(model).toObject(SharePointOnlineListResourceDataset.class);
- Assertions.assertEquals("mipvlxtyw", model.description());
- Assertions.assertEquals("rgkwiyoy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("fa").type());
- Assertions.assertEquals("d", model.folder().name());
+ Assertions.assertEquals("tcoojybolqox", model.description());
+ Assertions.assertEquals("mtykxszdekfxcsqm", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("orfji").type());
+ Assertions.assertEquals("zihirqvvketyd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListSourceTests.java
index ebb33c70f0aa..d8ef21480b70 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SharePointOnlineListSourceTests.java
@@ -11,18 +11,18 @@ public final class SharePointOnlineListSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SharePointOnlineListSource model = BinaryData.fromString(
- "{\"type\":\"SharePointOnlineListSource\",\"query\":\"datajiope\",\"httpRequestTimeout\":\"dataxgimfftvylfkec\",\"sourceRetryCount\":\"datafq\",\"sourceRetryWait\":\"databqdjawuldyjmjvzp\",\"maxConcurrentConnections\":\"datahba\",\"disableMetricsCollection\":\"datarriwrmd\",\"\":{\"tjyxhvjjvsvlmdl\":\"datasybvnqaxmipk\"}}")
+ "{\"type\":\"SharePointOnlineListSource\",\"query\":\"dataricjmvs\",\"httpRequestTimeout\":\"datadtladfc\",\"sourceRetryCount\":\"datazcizuegyl\",\"sourceRetryWait\":\"datamefpijwr\",\"maxConcurrentConnections\":\"datauphbwaiswb\",\"disableMetricsCollection\":\"datagrysjgz\",\"\":{\"eduxyd\":\"datajupdcmpfwfdc\"}}")
.toObject(SharePointOnlineListSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SharePointOnlineListSource model = new SharePointOnlineListSource().withSourceRetryCount("datafq")
- .withSourceRetryWait("databqdjawuldyjmjvzp")
- .withMaxConcurrentConnections("datahba")
- .withDisableMetricsCollection("datarriwrmd")
- .withQuery("datajiope")
- .withHttpRequestTimeout("dataxgimfftvylfkec");
+ SharePointOnlineListSource model = new SharePointOnlineListSource().withSourceRetryCount("datazcizuegyl")
+ .withSourceRetryWait("datamefpijwr")
+ .withMaxConcurrentConnections("datauphbwaiswb")
+ .withDisableMetricsCollection("datagrysjgz")
+ .withQuery("dataricjmvs")
+ .withHttpRequestTimeout("datadtladfc");
model = BinaryData.fromObject(model).toObject(SharePointOnlineListSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifyObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifyObjectDatasetTests.java
index 94d64b2b81e8..f8c488d9aed9 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifyObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifyObjectDatasetTests.java
@@ -19,32 +19,33 @@ public final class ShopifyObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ShopifyObjectDataset model = BinaryData.fromString(
- "{\"type\":\"ShopifyObject\",\"typeProperties\":{\"tableName\":\"dataybfmpotal\"},\"description\":\"figrxxtrco\",\"structure\":\"dataqe\",\"schema\":\"dataldmxxbjh\",\"linkedServiceName\":{\"referenceName\":\"pvamsxrwqlwdf\",\"parameters\":{\"bboffgxtae\":\"datarplzeqzv\",\"fcyatbxdwr\":\"dataxt\",\"fbpeigkflvovriq\":\"datayvtkmxvztshnu\"}},\"parameters\":{\"txur\":{\"type\":\"Float\",\"defaultValue\":\"datakqcgzygtdjhtbar\"}},\"annotations\":[\"datayyumhzpst\",\"datacqacvttyh\",\"databilnszyjbuw\"],\"folder\":{\"name\":\"sydsci\"},\"\":{\"l\":\"dataayioxpqgqs\",\"akqsjymcfv\":\"datalefeombodvdgf\",\"nbpkfnxrlncmlzvv\":\"datazceuyuqktck\",\"cjqzrevfwcba\":\"datamesfhqs\"}}")
+ "{\"type\":\"ShopifyObject\",\"typeProperties\":{\"tableName\":\"datandmtqvmkmzvag\"},\"description\":\"fblsxyfqgtodg\",\"structure\":\"datalefmizdcsr\",\"schema\":\"databnasgfyxhsxcg\",\"linkedServiceName\":{\"referenceName\":\"bmxbpqcnx\",\"parameters\":{\"uufhpdncokqrg\":\"datahojvmazuflfp\",\"fnmmib\":\"datavbhmnimjlyhb\",\"umqeobrwreu\":\"datawcduyrgcay\"}},\"parameters\":{\"aagwkrxjkcge\":{\"type\":\"Array\",\"defaultValue\":\"datahamigsqzmfk\"},\"t\":{\"type\":\"Float\",\"defaultValue\":\"databrfkjfkxn\"}},\"annotations\":[\"dataoeqcrjvcjskqsfn\",\"dataiwap\",\"dataunhdikatzmtuv\",\"datanh\"],\"folder\":{\"name\":\"kbibxlwzlvkcm\"},\"\":{\"aoboiahk\":\"dataaunlodincf\",\"ksaxyeedvpmodkt\":\"datapsvax\",\"mor\":\"datautydvvg\",\"yvuz\":\"datapcjes\"}}")
.toObject(ShopifyObjectDataset.class);
- Assertions.assertEquals("figrxxtrco", model.description());
- Assertions.assertEquals("pvamsxrwqlwdf", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("txur").type());
- Assertions.assertEquals("sydsci", model.folder().name());
+ Assertions.assertEquals("fblsxyfqgtodg", model.description());
+ Assertions.assertEquals("bmxbpqcnx", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("aagwkrxjkcge").type());
+ Assertions.assertEquals("kbibxlwzlvkcm", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ShopifyObjectDataset model = new ShopifyObjectDataset().withDescription("figrxxtrco")
- .withStructure("dataqe")
- .withSchema("dataldmxxbjh")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("pvamsxrwqlwdf")
- .withParameters(mapOf("bboffgxtae", "datarplzeqzv", "fcyatbxdwr", "dataxt", "fbpeigkflvovriq",
- "datayvtkmxvztshnu")))
- .withParameters(mapOf("txur",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datakqcgzygtdjhtbar")))
- .withAnnotations(Arrays.asList("datayyumhzpst", "datacqacvttyh", "databilnszyjbuw"))
- .withFolder(new DatasetFolder().withName("sydsci"))
- .withTableName("dataybfmpotal");
+ ShopifyObjectDataset model = new ShopifyObjectDataset().withDescription("fblsxyfqgtodg")
+ .withStructure("datalefmizdcsr")
+ .withSchema("databnasgfyxhsxcg")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bmxbpqcnx")
+ .withParameters(mapOf("uufhpdncokqrg", "datahojvmazuflfp", "fnmmib", "datavbhmnimjlyhb", "umqeobrwreu",
+ "datawcduyrgcay")))
+ .withParameters(mapOf("aagwkrxjkcge",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datahamigsqzmfk"), "t",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("databrfkjfkxn")))
+ .withAnnotations(Arrays.asList("dataoeqcrjvcjskqsfn", "dataiwap", "dataunhdikatzmtuv", "datanh"))
+ .withFolder(new DatasetFolder().withName("kbibxlwzlvkcm"))
+ .withTableName("datandmtqvmkmzvag");
model = BinaryData.fromObject(model).toObject(ShopifyObjectDataset.class);
- Assertions.assertEquals("figrxxtrco", model.description());
- Assertions.assertEquals("pvamsxrwqlwdf", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("txur").type());
- Assertions.assertEquals("sydsci", model.folder().name());
+ Assertions.assertEquals("fblsxyfqgtodg", model.description());
+ Assertions.assertEquals("bmxbpqcnx", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("aagwkrxjkcge").type());
+ Assertions.assertEquals("kbibxlwzlvkcm", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifySourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifySourceTests.java
index ca0525b10fc8..83830993657e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifySourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ShopifySourceTests.java
@@ -11,19 +11,19 @@ public final class ShopifySourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ShopifySource model = BinaryData.fromString(
- "{\"type\":\"ShopifySource\",\"query\":\"datadtq\",\"queryTimeout\":\"datajbxol\",\"additionalColumns\":\"datahquqihgibog\",\"sourceRetryCount\":\"datajupenoupcolxc\",\"sourceRetryWait\":\"dataszwadesisd\",\"maxConcurrentConnections\":\"datauhqts\",\"disableMetricsCollection\":\"datab\",\"\":{\"bymrgelgoduexx\":\"dataeeucvv\",\"fr\":\"datad\",\"wqzvqtnozwphka\":\"dataenvkqtvtq\",\"bzbbjxkami\":\"dataracvcbrtltpo\"}}")
+ "{\"type\":\"ShopifySource\",\"query\":\"databuwauytq\",\"queryTimeout\":\"datagaxloafws\",\"additionalColumns\":\"dataxqrokw\",\"sourceRetryCount\":\"dataipn\",\"sourceRetryWait\":\"dataql\",\"maxConcurrentConnections\":\"datarhctbrvegdamoy\",\"disableMetricsCollection\":\"datafjpkezqjizbyczme\",\"\":{\"destarulnhbqt\":\"datacgvlnpjjbyryrktu\",\"xhcrffj\":\"datayh\",\"svzhlkeot\":\"dataexupcuizvx\"}}")
.toObject(ShopifySource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ShopifySource model = new ShopifySource().withSourceRetryCount("datajupenoupcolxc")
- .withSourceRetryWait("dataszwadesisd")
- .withMaxConcurrentConnections("datauhqts")
- .withDisableMetricsCollection("datab")
- .withQueryTimeout("datajbxol")
- .withAdditionalColumns("datahquqihgibog")
- .withQuery("datadtq");
+ ShopifySource model = new ShopifySource().withSourceRetryCount("dataipn")
+ .withSourceRetryWait("dataql")
+ .withMaxConcurrentConnections("datarhctbrvegdamoy")
+ .withDisableMetricsCollection("datafjpkezqjizbyczme")
+ .withQueryTimeout("datagaxloafws")
+ .withAdditionalColumns("dataxqrokw")
+ .withQuery("databuwauytq");
model = BinaryData.fromObject(model).toObject(ShopifySource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SkipErrorFileTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SkipErrorFileTests.java
index f15ceeee71d9..51b970c7f1c7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SkipErrorFileTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SkipErrorFileTests.java
@@ -10,15 +10,13 @@
public final class SkipErrorFileTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SkipErrorFile model
- = BinaryData.fromString("{\"fileMissing\":\"datautdrrqqajhklttl\",\"dataInconsistency\":\"datawdrt\"}")
- .toObject(SkipErrorFile.class);
+ SkipErrorFile model = BinaryData.fromString("{\"fileMissing\":\"dataislep\",\"dataInconsistency\":\"datas\"}")
+ .toObject(SkipErrorFile.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SkipErrorFile model
- = new SkipErrorFile().withFileMissing("datautdrrqqajhklttl").withDataInconsistency("datawdrt");
+ SkipErrorFile model = new SkipErrorFile().withFileMissing("dataislep").withDataInconsistency("datas");
model = BinaryData.fromObject(model).toObject(SkipErrorFile.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTests.java
index 82c857a1bf76..376c237b024d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTests.java
@@ -19,33 +19,37 @@ public final class SnowflakeDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeDataset model = BinaryData.fromString(
- "{\"type\":\"SnowflakeTable\",\"typeProperties\":{\"schema\":\"dataqjfskjva\",\"table\":\"dataxrwkns\"},\"description\":\"hypbrzwiypz\",\"structure\":\"datahkecebtpgvutb\",\"schema\":\"datasfd\",\"linkedServiceName\":{\"referenceName\":\"wq\",\"parameters\":{\"dgrcifflxqqn\":\"dataowke\",\"ujticwmlf\":\"datagtcuyuwgnyjd\"}},\"parameters\":{\"ufpvvdgnmeiomn\":{\"type\":\"Float\",\"defaultValue\":\"datafmcoxbktuaj\"},\"i\":{\"type\":\"Float\",\"defaultValue\":\"dataaibcfbfyqz\"}},\"annotations\":[\"datafgvmrkmgifmy\",\"databuhdnhhcmtslptbd\",\"dataonhbl\"],\"folder\":{\"name\":\"cnuqfpzjz\"},\"\":{\"mruawqesqsqmiekx\":\"datacwtwtrchk\",\"qchf\":\"datap\",\"cu\":\"datatykkvjjlba\"}}")
+ "{\"type\":\"SnowflakeTable\",\"typeProperties\":{\"schema\":\"dataybfby\",\"table\":\"datalqllbofsn\"},\"description\":\"cybrhxgiknrl\",\"structure\":\"dataseiqbroqjfeamzku\",\"schema\":\"datagpksgotbunvnjqld\",\"linkedServiceName\":{\"referenceName\":\"qqvcugusqlxlxedt\",\"parameters\":{\"lnlmpuyypaggpaih\":\"datalnvqacbyfis\",\"ymipvlxty\":\"dataaeyzwloqrmgd\",\"pllitx\":\"dataukhjd\",\"qoivxcodw\":\"datargkwiyoy\"}},\"parameters\":{\"fwfiikqcdnzsfi\":{\"type\":\"Array\",\"defaultValue\":\"datacachhsizfuew\"},\"ah\":{\"type\":\"Int\",\"defaultValue\":\"dataneoodmcrxlyz\"},\"brnlsyiaan\":{\"type\":\"SecureString\",\"defaultValue\":\"datafakrxjjwnbrmdw\"}},\"annotations\":[\"datacjhatclpphc\",\"datatmrycpana\",\"datafa\",\"dataizrinlpxngzzxqb\"],\"folder\":{\"name\":\"zmzctbxzjk\"},\"\":{\"dozw\":\"datapucv\",\"e\":\"datask\",\"qmbinpxmiwt\":\"datafz\"}}")
.toObject(SnowflakeDataset.class);
- Assertions.assertEquals("hypbrzwiypz", model.description());
- Assertions.assertEquals("wq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("ufpvvdgnmeiomn").type());
- Assertions.assertEquals("cnuqfpzjz", model.folder().name());
+ Assertions.assertEquals("cybrhxgiknrl", model.description());
+ Assertions.assertEquals("qqvcugusqlxlxedt", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("fwfiikqcdnzsfi").type());
+ Assertions.assertEquals("zmzctbxzjk", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SnowflakeDataset model = new SnowflakeDataset().withDescription("hypbrzwiypz")
- .withStructure("datahkecebtpgvutb")
- .withSchema("datasfd")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("wq")
- .withParameters(mapOf("dgrcifflxqqn", "dataowke", "ujticwmlf", "datagtcuyuwgnyjd")))
- .withParameters(mapOf("ufpvvdgnmeiomn",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datafmcoxbktuaj"), "i",
- new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataaibcfbfyqz")))
- .withAnnotations(Arrays.asList("datafgvmrkmgifmy", "databuhdnhhcmtslptbd", "dataonhbl"))
- .withFolder(new DatasetFolder().withName("cnuqfpzjz"))
- .withSchemaTypePropertiesSchema("dataqjfskjva")
- .withTable("dataxrwkns");
+ SnowflakeDataset model = new SnowflakeDataset().withDescription("cybrhxgiknrl")
+ .withStructure("dataseiqbroqjfeamzku")
+ .withSchema("datagpksgotbunvnjqld")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qqvcugusqlxlxedt")
+ .withParameters(mapOf("lnlmpuyypaggpaih", "datalnvqacbyfis", "ymipvlxty", "dataaeyzwloqrmgd", "pllitx",
+ "dataukhjd", "qoivxcodw", "datargkwiyoy")))
+ .withParameters(mapOf("fwfiikqcdnzsfi",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datacachhsizfuew"), "ah",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataneoodmcrxlyz"),
+ "brnlsyiaan",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datafakrxjjwnbrmdw")))
+ .withAnnotations(Arrays.asList("datacjhatclpphc", "datatmrycpana", "datafa", "dataizrinlpxngzzxqb"))
+ .withFolder(new DatasetFolder().withName("zmzctbxzjk"))
+ .withSchemaTypePropertiesSchema("dataybfby")
+ .withTable("datalqllbofsn");
model = BinaryData.fromObject(model).toObject(SnowflakeDataset.class);
- Assertions.assertEquals("hypbrzwiypz", model.description());
- Assertions.assertEquals("wq", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("ufpvvdgnmeiomn").type());
- Assertions.assertEquals("cnuqfpzjz", model.folder().name());
+ Assertions.assertEquals("cybrhxgiknrl", model.description());
+ Assertions.assertEquals("qqvcugusqlxlxedt", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("fwfiikqcdnzsfi").type());
+ Assertions.assertEquals("zmzctbxzjk", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTypePropertiesTests.java
index 975bfad630c4..b035de9a2ebc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class SnowflakeDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeDatasetTypeProperties model
- = BinaryData.fromString("{\"schema\":\"datayqokbgumuejxxpx\",\"table\":\"datazch\"}")
+ = BinaryData.fromString("{\"schema\":\"dataifpvrdukcdnzo\",\"table\":\"dataabux\"}")
.toObject(SnowflakeDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SnowflakeDatasetTypeProperties model
- = new SnowflakeDatasetTypeProperties().withSchema("datayqokbgumuejxxpx").withTable("datazch");
+ = new SnowflakeDatasetTypeProperties().withSchema("dataifpvrdukcdnzo").withTable("dataabux");
model = BinaryData.fromObject(model).toObject(SnowflakeDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeExportCopyCommandTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeExportCopyCommandTests.java
index 55894b7952a3..87b66a354c17 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeExportCopyCommandTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeExportCopyCommandTests.java
@@ -13,17 +13,18 @@ public final class SnowflakeExportCopyCommandTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeExportCopyCommand model = BinaryData.fromString(
- "{\"type\":\"SnowflakeExportCopyCommand\",\"additionalCopyOptions\":{\"ajb\":\"datathnndfplksdieh\",\"sn\":\"datatgmxkol\"},\"additionalFormatOptions\":{\"yow\":\"datamkpxbckjrfkwclq\",\"cvrdjpvsc\":\"datadhtwaxobdzatq\",\"hocyvymvnla\":\"datawpsteuvjd\",\"bfomo\":\"datahitxo\"},\"storageIntegration\":\"dataynorhhbvbqxtk\",\"\":{\"pomoofbnbhptral\":\"datau\",\"ydmkyvsxcdivghaj\":\"datacqpupmath\",\"nmfmkpj\":\"dataddgfo\",\"zbmwptdr\":\"dataesozcuhunm\"}}")
+ "{\"type\":\"SnowflakeExportCopyCommand\",\"additionalCopyOptions\":{\"ofdhrifekstrmsb\":\"datawikmgwxysut\",\"nssmaaxzcdlnvup\":\"datadgrzkeuplorn\"},\"additionalFormatOptions\":{\"lvoyltmxqalq\":\"databzyhtbjyycaco\",\"jwwoxanefellhdsg\":\"datary\",\"cbvuvwdp\":\"datagdubwmalt\",\"hnaghglaxj\":\"datal\"},\"storageIntegration\":\"databmfm\",\"\":{\"dpicwnbt\":\"dataatswvt\",\"erkaiikbpf\":\"datalrsfmtrmodkn\",\"keyhjuaezkb\":\"dataqxpq\",\"tqvtpkod\":\"datavtaul\"}}")
.toObject(SnowflakeExportCopyCommand.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SnowflakeExportCopyCommand model = new SnowflakeExportCopyCommand()
- .withAdditionalCopyOptions(mapOf("ajb", "datathnndfplksdieh", "sn", "datatgmxkol"))
- .withAdditionalFormatOptions(mapOf("yow", "datamkpxbckjrfkwclq", "cvrdjpvsc", "datadhtwaxobdzatq",
- "hocyvymvnla", "datawpsteuvjd", "bfomo", "datahitxo"))
- .withStorageIntegration("dataynorhhbvbqxtk");
+ .withAdditionalCopyOptions(
+ mapOf("ofdhrifekstrmsb", "datawikmgwxysut", "nssmaaxzcdlnvup", "datadgrzkeuplorn"))
+ .withAdditionalFormatOptions(mapOf("lvoyltmxqalq", "databzyhtbjyycaco", "jwwoxanefellhdsg", "datary",
+ "cbvuvwdp", "datagdubwmalt", "hnaghglaxj", "datal"))
+ .withStorageIntegration("databmfm");
model = BinaryData.fromObject(model).toObject(SnowflakeExportCopyCommand.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeImportCopyCommandTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeImportCopyCommandTests.java
index 22e36c1b3e80..cd4dfbfa8374 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeImportCopyCommandTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeImportCopyCommandTests.java
@@ -13,17 +13,17 @@ public final class SnowflakeImportCopyCommandTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeImportCopyCommand model = BinaryData.fromString(
- "{\"type\":\"SnowflakeImportCopyCommand\",\"additionalCopyOptions\":{\"saqfnbxuw\":\"datahgyeoikxjpuwgg\"},\"additionalFormatOptions\":{\"egtsqzkzworuhhv\":\"databus\",\"bkgp\":\"dataeodcdjhf\",\"tyuvuzqtrfziub\":\"dataxusylgpznbklhw\"},\"storageIntegration\":\"datalvktjbmce\",\"\":{\"bwhjvonu\":\"dataukdawgz\",\"k\":\"datavygx\",\"jcjvdajxebm\":\"datatjoxocothsg\",\"nd\":\"dataiyrctfaabkukra\"}}")
+ "{\"type\":\"SnowflakeImportCopyCommand\",\"additionalCopyOptions\":{\"jozbdwf\":\"dataloxazywijbvqae\"},\"additionalFormatOptions\":{\"dletjiudcoktsgc\":\"datawliitaieledmiup\",\"grebecxuuzeuklu\":\"datapjlmsta\"},\"storageIntegration\":\"dataxejamychwwrv\",\"\":{\"nmgabfz\":\"dataxkttxvmbedvvmr\",\"hylzwzhlbp\":\"dataai\"}}")
.toObject(SnowflakeImportCopyCommand.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SnowflakeImportCopyCommand model
- = new SnowflakeImportCopyCommand().withAdditionalCopyOptions(mapOf("saqfnbxuw", "datahgyeoikxjpuwgg"))
+ = new SnowflakeImportCopyCommand().withAdditionalCopyOptions(mapOf("jozbdwf", "dataloxazywijbvqae"))
.withAdditionalFormatOptions(
- mapOf("egtsqzkzworuhhv", "databus", "bkgp", "dataeodcdjhf", "tyuvuzqtrfziub", "dataxusylgpznbklhw"))
- .withStorageIntegration("datalvktjbmce");
+ mapOf("dletjiudcoktsgc", "datawliitaieledmiup", "grebecxuuzeuklu", "datapjlmsta"))
+ .withStorageIntegration("dataxejamychwwrv");
model = BinaryData.fromObject(model).toObject(SnowflakeImportCopyCommand.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSinkTests.java
index 44daccae0fe1..4be59006ce66 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSinkTests.java
@@ -14,25 +14,24 @@ public final class SnowflakeSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeSink model = BinaryData.fromString(
- "{\"type\":\"SnowflakeSink\",\"preCopyScript\":\"datagwohkromzsse\",\"importSettings\":{\"type\":\"SnowflakeImportCopyCommand\",\"additionalCopyOptions\":{\"lvhbg\":\"datajyovr\",\"gpsalynan\":\"datagjpiezthf\",\"rxizorqliblybx\":\"datawzpfbiqjrz\"},\"additionalFormatOptions\":{\"zdyoznidstofded\":\"dataknkf\",\"biwxmcsxidaz\":\"datamfwabfgfw\",\"yikhdcilinbuok\":\"datalwh\"},\"storageIntegration\":\"dataperhei\",\"\":{\"oauu\":\"datamswhqrdvqva\"}},\"writeBatchSize\":\"dataigofumbp\",\"writeBatchTimeout\":\"dataedmfjgklm\",\"sinkRetryCount\":\"datamavb\",\"sinkRetryWait\":\"dataaoaixipcwyinfy\",\"maxConcurrentConnections\":\"dataqvjnoem\",\"disableMetricsCollection\":\"datautbyaeyyiwr\",\"\":{\"onridhwoyznjdd\":\"datapdmexugdjdmwcxvc\",\"ipuot\":\"datahazlomvx\",\"rhjh\":\"dataiqzqmpgvyydjww\",\"h\":\"datawcfftszswvyi\"}}")
+ "{\"type\":\"SnowflakeSink\",\"preCopyScript\":\"datazqtimqics\",\"importSettings\":{\"type\":\"SnowflakeImportCopyCommand\",\"additionalCopyOptions\":{\"ujwntnfoqwu\":\"datapjcpdtktfpjkx\",\"pnsyedpyrp\":\"dataoraxbeam\",\"odifghdgsyhncxoq\":\"datapslcfwgrzzqf\",\"soxxoqyik\":\"datatjzdpllgllvkorg\"},\"additionalFormatOptions\":{\"mttxqxvmybqjlg\":\"datao\",\"sdccmdplhzjiqi\":\"datalf\"},\"storageIntegration\":\"dataiwrhmzkxrqzgshqx\",\"\":{\"fslawimhoaqj\":\"datanu\",\"mdaiv\":\"datalhlpz\",\"zdipnhbs\":\"datazqz\",\"mnoasyyadyf\":\"datarlrcc\"}},\"writeBatchSize\":\"datatllnzcmdgsvaek\",\"writeBatchTimeout\":\"datavwiwtykprrddben\",\"sinkRetryCount\":\"datahfszmxposmqscvy\",\"sinkRetryWait\":\"datadkpdleeslj\",\"maxConcurrentConnections\":\"datapsubxggknmvkniqo\",\"disableMetricsCollection\":\"datarcpsjeaz\",\"\":{\"sddy\":\"datacsbkmaluchbfrtaj\",\"nzp\":\"datadx\",\"fpggi\":\"datak\",\"wtkqofrkfccqj\":\"dataxsyufexivhjyxa\"}}")
.toObject(SnowflakeSink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SnowflakeSink model = new SnowflakeSink().withWriteBatchSize("dataigofumbp")
- .withWriteBatchTimeout("dataedmfjgklm")
- .withSinkRetryCount("datamavb")
- .withSinkRetryWait("dataaoaixipcwyinfy")
- .withMaxConcurrentConnections("dataqvjnoem")
- .withDisableMetricsCollection("datautbyaeyyiwr")
- .withPreCopyScript("datagwohkromzsse")
+ SnowflakeSink model = new SnowflakeSink().withWriteBatchSize("datatllnzcmdgsvaek")
+ .withWriteBatchTimeout("datavwiwtykprrddben")
+ .withSinkRetryCount("datahfszmxposmqscvy")
+ .withSinkRetryWait("datadkpdleeslj")
+ .withMaxConcurrentConnections("datapsubxggknmvkniqo")
+ .withDisableMetricsCollection("datarcpsjeaz")
+ .withPreCopyScript("datazqtimqics")
.withImportSettings(new SnowflakeImportCopyCommand()
- .withAdditionalCopyOptions(
- mapOf("lvhbg", "datajyovr", "gpsalynan", "datagjpiezthf", "rxizorqliblybx", "datawzpfbiqjrz"))
- .withAdditionalFormatOptions(
- mapOf("zdyoznidstofded", "dataknkf", "biwxmcsxidaz", "datamfwabfgfw", "yikhdcilinbuok", "datalwh"))
- .withStorageIntegration("dataperhei"));
+ .withAdditionalCopyOptions(mapOf("ujwntnfoqwu", "datapjcpdtktfpjkx", "pnsyedpyrp", "dataoraxbeam",
+ "odifghdgsyhncxoq", "datapslcfwgrzzqf", "soxxoqyik", "datatjzdpllgllvkorg"))
+ .withAdditionalFormatOptions(mapOf("mttxqxvmybqjlg", "datao", "sdccmdplhzjiqi", "datalf"))
+ .withStorageIntegration("dataiwrhmzkxrqzgshqx"));
model = BinaryData.fromObject(model).toObject(SnowflakeSink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSourceTests.java
index ca8916562d85..9da93380b808 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeSourceTests.java
@@ -14,21 +14,22 @@ public final class SnowflakeSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeSource model = BinaryData.fromString(
- "{\"type\":\"SnowflakeSource\",\"query\":\"datayeyqsiniejjb\",\"exportSettings\":{\"type\":\"SnowflakeExportCopyCommand\",\"additionalCopyOptions\":{\"bdtmrijt\":\"datatxkwrvtlbbu\"},\"additionalFormatOptions\":{\"v\":\"datahvbpvizuuluilgm\"},\"storageIntegration\":\"datantjsmjxgqs\",\"\":{\"zcqgt\":\"datavaaruv\"}},\"sourceRetryCount\":\"datatlrmrtdz\",\"sourceRetryWait\":\"datajgovy\",\"maxConcurrentConnections\":\"datappswlept\",\"disableMetricsCollection\":\"databrkntfwxkeuyxgpc\",\"\":{\"pznoveab\":\"datamrdlc\",\"sdharsw\":\"datapaiqikz\",\"rdvtvt\":\"dataqmrpdx\"}}")
+ "{\"type\":\"SnowflakeSource\",\"query\":\"datalazvcfhiayrop\",\"exportSettings\":{\"type\":\"SnowflakeExportCopyCommand\",\"additionalCopyOptions\":{\"tkhyrwdsnpuo\":\"datazlqwbglytwz\",\"j\":\"dataorfpizyb\",\"xwls\":\"datapqatkzghwcywrb\"},\"additionalFormatOptions\":{\"jiezbmhsqy\":\"datafwf\"},\"storageIntegration\":\"datawbzhafcoayuq\",\"\":{\"yfjtsem\":\"dataghjmmjmmjnx\",\"ocyo\":\"dataidbaykvlrsbrn\",\"mbch\":\"datap\",\"ybugojzcargsxmaw\":\"dataskwaffsjqnjp\"}},\"sourceRetryCount\":\"dataaagazryyjjwggpc\",\"sourceRetryWait\":\"datagwddobpcsjwex\",\"maxConcurrentConnections\":\"datazmm\",\"disableMetricsCollection\":\"dataqifhyhzu\",\"\":{\"hxcrweeqkdmp\":\"dataqnmhfmllorvh\",\"njftnfdcjtvei\":\"datamcrcel\"}}")
.toObject(SnowflakeSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SnowflakeSource model = new SnowflakeSource().withSourceRetryCount("datatlrmrtdz")
- .withSourceRetryWait("datajgovy")
- .withMaxConcurrentConnections("datappswlept")
- .withDisableMetricsCollection("databrkntfwxkeuyxgpc")
- .withQuery("datayeyqsiniejjb")
- .withExportSettings(
- new SnowflakeExportCopyCommand().withAdditionalCopyOptions(mapOf("bdtmrijt", "datatxkwrvtlbbu"))
- .withAdditionalFormatOptions(mapOf("v", "datahvbpvizuuluilgm"))
- .withStorageIntegration("datantjsmjxgqs"));
+ SnowflakeSource model = new SnowflakeSource().withSourceRetryCount("dataaagazryyjjwggpc")
+ .withSourceRetryWait("datagwddobpcsjwex")
+ .withMaxConcurrentConnections("datazmm")
+ .withDisableMetricsCollection("dataqifhyhzu")
+ .withQuery("datalazvcfhiayrop")
+ .withExportSettings(new SnowflakeExportCopyCommand()
+ .withAdditionalCopyOptions(
+ mapOf("tkhyrwdsnpuo", "datazlqwbglytwz", "j", "dataorfpizyb", "xwls", "datapqatkzghwcywrb"))
+ .withAdditionalFormatOptions(mapOf("jiezbmhsqy", "datafwf"))
+ .withStorageIntegration("datawbzhafcoayuq"));
model = BinaryData.fromObject(model).toObject(SnowflakeSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2DatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2DatasetTests.java
index 3910eae26736..40334c55caf6 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2DatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2DatasetTests.java
@@ -19,37 +19,34 @@ public final class SnowflakeV2DatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeV2Dataset model = BinaryData.fromString(
- "{\"type\":\"SnowflakeV2Table\",\"typeProperties\":{\"schema\":\"datauzginrkjkn\",\"table\":\"datafsu\"},\"description\":\"ybhozlsbufnhb\",\"structure\":\"datantpoe\",\"schema\":\"datatrsljzmzuic\",\"linkedServiceName\":{\"referenceName\":\"ggsxznb\",\"parameters\":{\"njl\":\"datakqbylb\",\"nitvkyahfoyfzo\":\"dataicqomanefwl\",\"cjukfalwc\":\"datadyaepre\",\"cayvqbeqpu\":\"dataec\"}},\"parameters\":{\"hicrjriy\":{\"type\":\"Int\",\"defaultValue\":\"datayl\"},\"nqocybrhxgiknrlu\":{\"type\":\"Array\",\"defaultValue\":\"dataydrlqllbof\"},\"xdgpksgo\":{\"type\":\"SecureString\",\"defaultValue\":\"dataiqbroqjfeamzk\"}},\"annotations\":[\"datanvnj\",\"dataldrqqv\",\"dataugusqlx\"],\"folder\":{\"name\":\"dthfwlnvqa\"},\"\":{\"ggpaiheaeyzwloq\":\"datafisblnlmpuyyp\"}}")
+ "{\"type\":\"SnowflakeV2Table\",\"typeProperties\":{\"schema\":\"datagba\",\"table\":\"datahramq\"},\"description\":\"gqcglmadfztofxvq\",\"structure\":\"datauuagwayfmcer\",\"schema\":\"datafeiqb\",\"linkedServiceName\":{\"referenceName\":\"s\",\"parameters\":{\"ozzjkugpd\":\"datawjipssvnonijcqc\",\"bpwarh\":\"dataqbtokvocuzxl\",\"i\":\"dataettohgpzwxyvtkzb\"}},\"parameters\":{\"wnfhmjusuqnku\":{\"type\":\"Bool\",\"defaultValue\":\"datadd\"},\"qnirmidtvhjcgs\":{\"type\":\"Array\",\"defaultValue\":\"datalxudhek\"}},\"annotations\":[\"dataqygkx\",\"datalfoj\"],\"folder\":{\"name\":\"pum\"},\"\":{\"rvykduumwbcu\":\"databod\",\"e\":\"dataj\"}}")
.toObject(SnowflakeV2Dataset.class);
- Assertions.assertEquals("ybhozlsbufnhb", model.description());
- Assertions.assertEquals("ggsxznb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("hicrjriy").type());
- Assertions.assertEquals("dthfwlnvqa", model.folder().name());
+ Assertions.assertEquals("gqcglmadfztofxvq", model.description());
+ Assertions.assertEquals("s", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("wnfhmjusuqnku").type());
+ Assertions.assertEquals("pum", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SnowflakeV2Dataset model = new SnowflakeV2Dataset().withDescription("ybhozlsbufnhb")
- .withStructure("datantpoe")
- .withSchema("datatrsljzmzuic")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ggsxznb")
- .withParameters(mapOf("njl", "datakqbylb", "nitvkyahfoyfzo", "dataicqomanefwl", "cjukfalwc",
- "datadyaepre", "cayvqbeqpu", "dataec")))
- .withParameters(mapOf("hicrjriy",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datayl"), "nqocybrhxgiknrlu",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataydrlqllbof"),
- "xdgpksgo",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("dataiqbroqjfeamzk")))
- .withAnnotations(Arrays.asList("datanvnj", "dataldrqqv", "dataugusqlx"))
- .withFolder(new DatasetFolder().withName("dthfwlnvqa"))
- .withSchemaTypePropertiesSchema("datauzginrkjkn")
- .withTable("datafsu");
+ SnowflakeV2Dataset model = new SnowflakeV2Dataset().withDescription("gqcglmadfztofxvq")
+ .withStructure("datauuagwayfmcer")
+ .withSchema("datafeiqb")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("s")
+ .withParameters(mapOf("ozzjkugpd", "datawjipssvnonijcqc", "bpwarh", "dataqbtokvocuzxl", "i",
+ "dataettohgpzwxyvtkzb")))
+ .withParameters(mapOf("wnfhmjusuqnku",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datadd"), "qnirmidtvhjcgs",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datalxudhek")))
+ .withAnnotations(Arrays.asList("dataqygkx", "datalfoj"))
+ .withFolder(new DatasetFolder().withName("pum"))
+ .withSchemaTypePropertiesSchema("datagba")
+ .withTable("datahramq");
model = BinaryData.fromObject(model).toObject(SnowflakeV2Dataset.class);
- Assertions.assertEquals("ybhozlsbufnhb", model.description());
- Assertions.assertEquals("ggsxznb", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("hicrjriy").type());
- Assertions.assertEquals("dthfwlnvqa", model.folder().name());
+ Assertions.assertEquals("gqcglmadfztofxvq", model.description());
+ Assertions.assertEquals("s", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("wnfhmjusuqnku").type());
+ Assertions.assertEquals("pum", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SinkTests.java
index 9071bd2b121f..ba71202e4099 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SinkTests.java
@@ -14,25 +14,25 @@ public final class SnowflakeV2SinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeV2Sink model = BinaryData.fromString(
- "{\"type\":\"SnowflakeV2Sink\",\"preCopyScript\":\"datawdicntqsrhac\",\"importSettings\":{\"type\":\"SnowflakeImportCopyCommand\",\"additionalCopyOptions\":{\"uyffkayovljtrml\":\"datadhjdwfnbiyxqr\",\"wwbqukjithx\":\"datarqllugnxmbwdkz\",\"tbfmtbprt\":\"datapvpkvceiwcfshhc\",\"qbwgmznvlwcn\":\"datavuxwuepjcugwku\"},\"additionalFormatOptions\":{\"bwzzxetxzcjrbs\":\"datakieyqp\",\"oxfchune\":\"datacwnbxqkbeoo\",\"vkkgxilxlon\":\"datakssxpnhhlhprjcf\"},\"storageIntegration\":\"datafdfs\",\"\":{\"dhqkariatxhpxdvr\":\"datawdnghdnrt\"}},\"writeBatchSize\":\"dataoghg\",\"writeBatchTimeout\":\"datazbzsasgam\",\"sinkRetryCount\":\"dataetxnsgcwad\",\"sinkRetryWait\":\"dataqbageltffqalmcq\",\"maxConcurrentConnections\":\"datapzwwtcwbgmx\",\"disableMetricsCollection\":\"dataynslcty\",\"\":{\"kmhhqwwtarxtdgp\":\"dataz\"}}")
+ "{\"type\":\"SnowflakeV2Sink\",\"preCopyScript\":\"datalethe\",\"importSettings\":{\"type\":\"SnowflakeImportCopyCommand\",\"additionalCopyOptions\":{\"onsvjc\":\"dataamtvooaacef\",\"ywi\":\"dataytytyrvtuxv\",\"kfqznvahpxdg\":\"datammmgbynvoytdt\"},\"additionalFormatOptions\":{\"aztoias\":\"datawxcptxvxfwwvmygc\",\"camgjyt\":\"datajri\",\"bmnxpmoadjoo\":\"datakttit\",\"bpuoycawptxq\":\"datarnzlzzmygoutq\"},\"storageIntegration\":\"dataufdxpwj\",\"\":{\"cuk\":\"datavskpbuoc\",\"cepp\":\"datatcuvwwfgjjcaa\"}},\"writeBatchSize\":\"datailyxpqxnlifhjym\",\"writeBatchTimeout\":\"datajliivyatyzwy\",\"sinkRetryCount\":\"dataaycjphozymcypdbu\",\"sinkRetryWait\":\"datanktlzngidgwsc\",\"maxConcurrentConnections\":\"datamhgzapcgdk\",\"disableMetricsCollection\":\"dataa\",\"\":{\"bbyoudct\":\"datapohlfvsbaqdgzb\",\"muomdl\":\"datalkucxtyufsouhkmc\",\"lxoxwndfuyj\":\"datapsbgxpnygroqia\"}}")
.toObject(SnowflakeV2Sink.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SnowflakeV2Sink model = new SnowflakeV2Sink().withWriteBatchSize("dataoghg")
- .withWriteBatchTimeout("datazbzsasgam")
- .withSinkRetryCount("dataetxnsgcwad")
- .withSinkRetryWait("dataqbageltffqalmcq")
- .withMaxConcurrentConnections("datapzwwtcwbgmx")
- .withDisableMetricsCollection("dataynslcty")
- .withPreCopyScript("datawdicntqsrhac")
+ SnowflakeV2Sink model = new SnowflakeV2Sink().withWriteBatchSize("datailyxpqxnlifhjym")
+ .withWriteBatchTimeout("datajliivyatyzwy")
+ .withSinkRetryCount("dataaycjphozymcypdbu")
+ .withSinkRetryWait("datanktlzngidgwsc")
+ .withMaxConcurrentConnections("datamhgzapcgdk")
+ .withDisableMetricsCollection("dataa")
+ .withPreCopyScript("datalethe")
.withImportSettings(new SnowflakeImportCopyCommand()
- .withAdditionalCopyOptions(mapOf("uyffkayovljtrml", "datadhjdwfnbiyxqr", "wwbqukjithx",
- "datarqllugnxmbwdkz", "tbfmtbprt", "datapvpkvceiwcfshhc", "qbwgmznvlwcn", "datavuxwuepjcugwku"))
- .withAdditionalFormatOptions(mapOf("bwzzxetxzcjrbs", "datakieyqp", "oxfchune", "datacwnbxqkbeoo",
- "vkkgxilxlon", "datakssxpnhhlhprjcf"))
- .withStorageIntegration("datafdfs"));
+ .withAdditionalCopyOptions(
+ mapOf("onsvjc", "dataamtvooaacef", "ywi", "dataytytyrvtuxv", "kfqznvahpxdg", "datammmgbynvoytdt"))
+ .withAdditionalFormatOptions(mapOf("aztoias", "datawxcptxvxfwwvmygc", "camgjyt", "datajri",
+ "bmnxpmoadjoo", "datakttit", "bpuoycawptxq", "datarnzlzzmygoutq"))
+ .withStorageIntegration("dataufdxpwj"));
model = BinaryData.fromObject(model).toObject(SnowflakeV2Sink.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SourceTests.java
index f5b6a18f989d..f3dc9f4c026e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SnowflakeV2SourceTests.java
@@ -14,22 +14,22 @@ public final class SnowflakeV2SourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SnowflakeV2Source model = BinaryData.fromString(
- "{\"type\":\"SnowflakeV2Source\",\"query\":\"datavo\",\"exportSettings\":{\"type\":\"SnowflakeExportCopyCommand\",\"additionalCopyOptions\":{\"eas\":\"datakmgp\",\"wdosfgbvsoz\":\"datadqpwhp\",\"tlb\":\"datafnpwxcjci\",\"oyl\":\"datauemqetmotuvhhed\"},\"additionalFormatOptions\":{\"wcca\":\"datal\"},\"storageIntegration\":\"datahbdvsorvhbygwtl\",\"\":{\"t\":\"datazzkbxwncggamx\",\"lexvqhbnwmokzx\":\"dataizydaiolnkkg\",\"e\":\"dataltbpqjfoujeiagny\",\"wyffut\":\"datajssay\"}},\"sourceRetryCount\":\"dataxrpxdhzwdy\",\"sourceRetryWait\":\"datayhvx\",\"maxConcurrentConnections\":\"dataexwhoscinpmvcvnm\",\"disableMetricsCollection\":\"datalshglym\",\"\":{\"hiayro\":\"dataazvc\",\"glytwzttkhyrwd\":\"dataxeezlqw\",\"pqatkzghwcywrb\":\"datanpuoaorfpizybpj\",\"kf\":\"dataxwls\"}}")
+ "{\"type\":\"SnowflakeV2Source\",\"query\":\"datavscndbklscokafaq\",\"exportSettings\":{\"type\":\"SnowflakeExportCopyCommand\",\"additionalCopyOptions\":{\"zsss\":\"datavnv\",\"qkotxodbxzhadm\":\"datancghgi\",\"yy\":\"datajnnoot\"},\"additionalFormatOptions\":{\"dhnzkmjoybyog\":\"dataqdo\",\"jewxphnlweyzvri\":\"datajrssnrykkhxawoh\"},\"storageIntegration\":\"dataveserltlhcjgjuop\",\"\":{\"f\":\"datamspk\",\"weiqvhfyvkxgo\":\"datadmbxfy\",\"cuxwnojvcrgqmbn\":\"datasvei\"}},\"sourceRetryCount\":\"dataygttdcfj\",\"sourceRetryWait\":\"datapsy\",\"maxConcurrentConnections\":\"datacksznngguucp\",\"disableMetricsCollection\":\"datasxnujwffthbzii\",\"\":{\"c\":\"datalbcc\",\"bdevjrbgcdx\":\"dataau\"}}")
.toObject(SnowflakeV2Source.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SnowflakeV2Source model = new SnowflakeV2Source().withSourceRetryCount("dataxrpxdhzwdy")
- .withSourceRetryWait("datayhvx")
- .withMaxConcurrentConnections("dataexwhoscinpmvcvnm")
- .withDisableMetricsCollection("datalshglym")
- .withQuery("datavo")
+ SnowflakeV2Source model = new SnowflakeV2Source().withSourceRetryCount("dataygttdcfj")
+ .withSourceRetryWait("datapsy")
+ .withMaxConcurrentConnections("datacksznngguucp")
+ .withDisableMetricsCollection("datasxnujwffthbzii")
+ .withQuery("datavscndbklscokafaq")
.withExportSettings(new SnowflakeExportCopyCommand()
- .withAdditionalCopyOptions(mapOf("eas", "datakmgp", "wdosfgbvsoz", "datadqpwhp", "tlb", "datafnpwxcjci",
- "oyl", "datauemqetmotuvhhed"))
- .withAdditionalFormatOptions(mapOf("wcca", "datal"))
- .withStorageIntegration("datahbdvsorvhbygwtl"));
+ .withAdditionalCopyOptions(mapOf("zsss", "datavnv", "qkotxodbxzhadm", "datancghgi", "yy", "datajnnoot"))
+ .withAdditionalFormatOptions(
+ mapOf("dhnzkmjoybyog", "dataqdo", "jewxphnlweyzvri", "datajrssnrykkhxawoh"))
+ .withStorageIntegration("dataveserltlhcjgjuop"));
model = BinaryData.fromObject(model).toObject(SnowflakeV2Source.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkConfigurationParametrizationReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkConfigurationParametrizationReferenceTests.java
index c5915476080b..d414848ec8b5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkConfigurationParametrizationReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkConfigurationParametrizationReferenceTests.java
@@ -13,7 +13,7 @@ public final class SparkConfigurationParametrizationReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SparkConfigurationParametrizationReference model
- = BinaryData.fromString("{\"type\":\"SparkConfigurationReference\",\"referenceName\":\"datazfrbd\"}")
+ = BinaryData.fromString("{\"type\":\"SparkConfigurationReference\",\"referenceName\":\"datarbdhrkhf\"}")
.toObject(SparkConfigurationParametrizationReference.class);
Assertions.assertEquals(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE, model.type());
}
@@ -22,7 +22,7 @@ public void testDeserialize() throws Exception {
public void testSerialize() throws Exception {
SparkConfigurationParametrizationReference model = new SparkConfigurationParametrizationReference()
.withType(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE)
- .withReferenceName("datazfrbd");
+ .withReferenceName("datarbdhrkhf");
model = BinaryData.fromObject(model).toObject(SparkConfigurationParametrizationReference.class);
Assertions.assertEquals(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE, model.type());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkDatasetTypePropertiesTests.java
index 36f8fb7a0d13..37b3665b3e04 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkDatasetTypePropertiesTests.java
@@ -11,16 +11,15 @@ public final class SparkDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SparkDatasetTypeProperties model = BinaryData
- .fromString(
- "{\"tableName\":\"datau\",\"table\":\"dataodincfbaoboiahk\",\"schema\":\"datasvaxmksaxyeedvp\"}")
+ .fromString("{\"tableName\":\"datawvbqcaww\",\"table\":\"dataqtsrnyotgnmz\",\"schema\":\"datacreluedcmk\"}")
.toObject(SparkDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SparkDatasetTypeProperties model = new SparkDatasetTypeProperties().withTableName("datau")
- .withTable("dataodincfbaoboiahk")
- .withSchema("datasvaxmksaxyeedvp");
+ SparkDatasetTypeProperties model = new SparkDatasetTypeProperties().withTableName("datawvbqcaww")
+ .withTable("dataqtsrnyotgnmz")
+ .withSchema("datacreluedcmk");
model = BinaryData.fromObject(model).toObject(SparkDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkObjectDatasetTests.java
index d2d1f9234067..043b5ba76691 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkObjectDatasetTests.java
@@ -19,36 +19,38 @@ public final class SparkObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SparkObjectDataset model = BinaryData.fromString(
- "{\"type\":\"SparkObject\",\"typeProperties\":{\"tableName\":\"datandmtqvmkmzvag\",\"table\":\"datafblsxyfqgtodg\",\"schema\":\"datalefmizdcsr\"},\"description\":\"bnasgfyxhsxcg\",\"structure\":\"datam\",\"schema\":\"datapqcnxs\",\"linkedServiceName\":{\"referenceName\":\"ehojvmazu\",\"parameters\":{\"hpdnc\":\"datapiuu\",\"h\":\"datakqrgiv\"}},\"parameters\":{\"uyrgcaygumqeo\":{\"type\":\"Bool\",\"defaultValue\":\"datalyhbjfnmmibgwc\"},\"sawha\":{\"type\":\"Float\",\"defaultValue\":\"datareud\"},\"zmfk\":{\"type\":\"Float\",\"defaultValue\":\"datas\"},\"k\":{\"type\":\"Int\",\"defaultValue\":\"datag\"}},\"annotations\":[\"datakcge\",\"datanubr\"],\"folder\":{\"name\":\"fkxnwt\"},\"\":{\"iwap\":\"dataoeqcrjvcjskqsfn\",\"nh\":\"dataunhdikatzmtuv\",\"ibxl\":\"datatjk\",\"u\":\"datazlvkcm\"}}")
+ "{\"type\":\"SparkObject\",\"typeProperties\":{\"tableName\":\"datavmshkkgygfohrm\",\"table\":\"datahlclpkr\",\"schema\":\"datacbmjjviutivr\"},\"description\":\"ztxt\",\"structure\":\"datamgftjviiloh\",\"schema\":\"datarjcxhhfhznsjx\",\"linkedServiceName\":{\"referenceName\":\"fo\",\"parameters\":{\"sxhdkhm\":\"datauylyumbweprlnuo\",\"lyfzmnxr\":\"datamxkahapesnbyou\",\"fwzlmpx\":\"dataxxjvwbatjgzkm\"}},\"parameters\":{\"mmdzphxulx\":{\"type\":\"Bool\",\"defaultValue\":\"datai\"},\"cpbzxpz\":{\"type\":\"SecureString\",\"defaultValue\":\"datadnpfcghdttowqx\"},\"feomotquqlq\":{\"type\":\"Bool\",\"defaultValue\":\"datavhatiywtcvzuzp\"}},\"annotations\":[\"datasgqp\"],\"folder\":{\"name\":\"dpfvlsqmmetwtla\"},\"\":{\"cgrllyyfsmoc\":\"datajtefbdpnuvh\",\"chmetvzhuugdykgd\":\"dataxh\"}}")
.toObject(SparkObjectDataset.class);
- Assertions.assertEquals("bnasgfyxhsxcg", model.description());
- Assertions.assertEquals("ehojvmazu", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("uyrgcaygumqeo").type());
- Assertions.assertEquals("fkxnwt", model.folder().name());
+ Assertions.assertEquals("ztxt", model.description());
+ Assertions.assertEquals("fo", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("mmdzphxulx").type());
+ Assertions.assertEquals("dpfvlsqmmetwtla", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SparkObjectDataset model = new SparkObjectDataset().withDescription("bnasgfyxhsxcg")
- .withStructure("datam")
- .withSchema("datapqcnxs")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ehojvmazu")
- .withParameters(mapOf("hpdnc", "datapiuu", "h", "datakqrgiv")))
- .withParameters(mapOf("uyrgcaygumqeo",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datalyhbjfnmmibgwc"),
- "sawha", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datareud"),
- "zmfk", new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datas"), "k",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datag")))
- .withAnnotations(Arrays.asList("datakcge", "datanubr"))
- .withFolder(new DatasetFolder().withName("fkxnwt"))
- .withTableName("datandmtqvmkmzvag")
- .withTable("datafblsxyfqgtodg")
- .withSchemaTypePropertiesSchema("datalefmizdcsr");
+ SparkObjectDataset model = new SparkObjectDataset().withDescription("ztxt")
+ .withStructure("datamgftjviiloh")
+ .withSchema("datarjcxhhfhznsjx")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("fo")
+ .withParameters(mapOf("sxhdkhm", "datauylyumbweprlnuo", "lyfzmnxr", "datamxkahapesnbyou", "fwzlmpx",
+ "dataxxjvwbatjgzkm")))
+ .withParameters(mapOf("mmdzphxulx",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datai"), "cpbzxpz",
+ new ParameterSpecification().withType(ParameterType.SECURE_STRING)
+ .withDefaultValue("datadnpfcghdttowqx"),
+ "feomotquqlq",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datavhatiywtcvzuzp")))
+ .withAnnotations(Arrays.asList("datasgqp"))
+ .withFolder(new DatasetFolder().withName("dpfvlsqmmetwtla"))
+ .withTableName("datavmshkkgygfohrm")
+ .withTable("datahlclpkr")
+ .withSchemaTypePropertiesSchema("datacbmjjviutivr");
model = BinaryData.fromObject(model).toObject(SparkObjectDataset.class);
- Assertions.assertEquals("bnasgfyxhsxcg", model.description());
- Assertions.assertEquals("ehojvmazu", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("uyrgcaygumqeo").type());
- Assertions.assertEquals("fkxnwt", model.folder().name());
+ Assertions.assertEquals("ztxt", model.description());
+ Assertions.assertEquals("fo", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("mmdzphxulx").type());
+ Assertions.assertEquals("dpfvlsqmmetwtla", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkSourceTests.java
index a95b369c38ec..14c584d162d3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SparkSourceTests.java
@@ -11,19 +11,19 @@ public final class SparkSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SparkSource model = BinaryData.fromString(
- "{\"type\":\"SparkSource\",\"query\":\"datav\",\"queryTimeout\":\"datapdv\",\"additionalColumns\":\"datayelrteunkwypu\",\"sourceRetryCount\":\"datafmsygt\",\"sourceRetryWait\":\"dataqlfdml\",\"maxConcurrentConnections\":\"datazdbrw\",\"disableMetricsCollection\":\"datawft\",\"\":{\"jsfgkwrcbgxypr\":\"dataxwi\",\"izabjb\":\"databpywecz\"}}")
+ "{\"type\":\"SparkSource\",\"query\":\"datacq\",\"queryTimeout\":\"datazrflo\",\"additionalColumns\":\"datamvemliyddfqfn\",\"sourceRetryCount\":\"datarrhhgw\",\"sourceRetryWait\":\"dataizhanvcfxd\",\"maxConcurrentConnections\":\"datad\",\"disableMetricsCollection\":\"datagctxu\",\"\":{\"dyya\":\"datahqqvd\"}}")
.toObject(SparkSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SparkSource model = new SparkSource().withSourceRetryCount("datafmsygt")
- .withSourceRetryWait("dataqlfdml")
- .withMaxConcurrentConnections("datazdbrw")
- .withDisableMetricsCollection("datawft")
- .withQueryTimeout("datapdv")
- .withAdditionalColumns("datayelrteunkwypu")
- .withQuery("datav");
+ SparkSource model = new SparkSource().withSourceRetryCount("datarrhhgw")
+ .withSourceRetryWait("dataizhanvcfxd")
+ .withMaxConcurrentConnections("datad")
+ .withDisableMetricsCollection("datagctxu")
+ .withQueryTimeout("datazrflo")
+ .withAdditionalColumns("datamvemliyddfqfn")
+ .withQuery("datacq");
model = BinaryData.fromObject(model).toObject(SparkSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlDWSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlDWSourceTests.java
index 81bb8f0d87ee..2a33c7f9ee71 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlDWSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlDWSourceTests.java
@@ -12,26 +12,26 @@ public final class SqlDWSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlDWSource model = BinaryData.fromString(
- "{\"type\":\"SqlDWSource\",\"sqlReaderQuery\":\"dataqfaxtl\",\"sqlReaderStoredProcedureName\":\"datayzcgugslpvy\",\"storedProcedureParameters\":\"datafuhfa\",\"isolationLevel\":\"dataibvslocdkp\",\"partitionOption\":\"datakq\",\"partitionSettings\":{\"partitionColumnName\":\"datadxnzjz\",\"partitionUpperBound\":\"datahhiztfmibwzuhyd\",\"partitionLowerBound\":\"datackgwtbfxxsfjn\"},\"queryTimeout\":\"datascjig\",\"additionalColumns\":\"datakdsvayyhtiy\",\"sourceRetryCount\":\"datahmniz\",\"sourceRetryWait\":\"databtehkytl\",\"maxConcurrentConnections\":\"datamyznwrcfqwkqul\",\"disableMetricsCollection\":\"dataovqohwiw\",\"\":{\"sjjjcd\":\"dataxjxlssosndnypx\",\"xb\":\"datasvgdbfni\",\"jgczpdio\":\"datasjhpm\",\"cwmabehr\":\"datadtjylimzvjwjhmtc\"}}")
+ "{\"type\":\"SqlDWSource\",\"sqlReaderQuery\":\"datatmhwgencmoswcxlg\",\"sqlReaderStoredProcedureName\":\"datauqxews\",\"storedProcedureParameters\":\"datapifzavctywappa\",\"isolationLevel\":\"dataprzrsqcu\",\"partitionOption\":\"datanp\",\"partitionSettings\":{\"partitionColumnName\":\"datal\",\"partitionUpperBound\":\"datau\",\"partitionLowerBound\":\"datasrnps\"},\"queryTimeout\":\"dataghoeqiwpdxp\",\"additionalColumns\":\"datasoajqxyplhsto\",\"sourceRetryCount\":\"datayb\",\"sourceRetryWait\":\"dataysvpikgqjdog\",\"maxConcurrentConnections\":\"datacjfgy\",\"disableMetricsCollection\":\"datas\",\"\":{\"pqp\":\"dataxcx\",\"yjch\":\"datainiidaxbesbwci\",\"q\":\"datauasjrs\"}}")
.toObject(SqlDWSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlDWSource model = new SqlDWSource().withSourceRetryCount("datahmniz")
- .withSourceRetryWait("databtehkytl")
- .withMaxConcurrentConnections("datamyznwrcfqwkqul")
- .withDisableMetricsCollection("dataovqohwiw")
- .withQueryTimeout("datascjig")
- .withAdditionalColumns("datakdsvayyhtiy")
- .withSqlReaderQuery("dataqfaxtl")
- .withSqlReaderStoredProcedureName("datayzcgugslpvy")
- .withStoredProcedureParameters("datafuhfa")
- .withIsolationLevel("dataibvslocdkp")
- .withPartitionOption("datakq")
- .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datadxnzjz")
- .withPartitionUpperBound("datahhiztfmibwzuhyd")
- .withPartitionLowerBound("datackgwtbfxxsfjn"));
+ SqlDWSource model = new SqlDWSource().withSourceRetryCount("datayb")
+ .withSourceRetryWait("dataysvpikgqjdog")
+ .withMaxConcurrentConnections("datacjfgy")
+ .withDisableMetricsCollection("datas")
+ .withQueryTimeout("dataghoeqiwpdxp")
+ .withAdditionalColumns("datasoajqxyplhsto")
+ .withSqlReaderQuery("datatmhwgencmoswcxlg")
+ .withSqlReaderStoredProcedureName("datauqxews")
+ .withStoredProcedureParameters("datapifzavctywappa")
+ .withIsolationLevel("dataprzrsqcu")
+ .withPartitionOption("datanp")
+ .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datal")
+ .withPartitionUpperBound("datau")
+ .withPartitionLowerBound("datasrnps"));
model = BinaryData.fromObject(model).toObject(SqlDWSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlMISourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlMISourceTests.java
index 1f458ed534a6..02c4fd508813 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlMISourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlMISourceTests.java
@@ -12,27 +12,27 @@ public final class SqlMISourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlMISource model = BinaryData.fromString(
- "{\"type\":\"SqlMISource\",\"sqlReaderQuery\":\"datarjmicha\",\"sqlReaderStoredProcedureName\":\"dataen\",\"storedProcedureParameters\":\"dataqjvdde\",\"isolationLevel\":\"datavrjhtpxydiuviup\",\"produceAdditionalTypes\":\"datatnsyrrybdyqiv\",\"partitionOption\":\"datasuhozihd\",\"partitionSettings\":{\"partitionColumnName\":\"datajwthwcpijgasnafd\",\"partitionUpperBound\":\"datanwgirnjgso\",\"partitionLowerBound\":\"databdhrcepanhygca\"},\"queryTimeout\":\"datajbjjlxsv\",\"additionalColumns\":\"databggsnanojty\",\"sourceRetryCount\":\"datahzxzazofr\",\"sourceRetryWait\":\"datasxjdgaimk\",\"maxConcurrentConnections\":\"datasowszb\",\"disableMetricsCollection\":\"datalhxik\",\"\":{\"tzjxgassmnatnp\":\"datakyngarwz\",\"gek\":\"datalueylqysgmiix\",\"hlgpe\":\"datawecbqtkdgin\",\"cqgqrsopq\":\"dataqqcceyowrwvbqv\"}}")
+ "{\"type\":\"SqlMISource\",\"sqlReaderQuery\":\"datardtrdukdmsktuv\",\"sqlReaderStoredProcedureName\":\"datazxtvytoyf\",\"storedProcedureParameters\":\"datagrzwdwdudxqeb\",\"isolationLevel\":\"datapsplwtlocseybv\",\"produceAdditionalTypes\":\"datacoznnjqxck\",\"partitionOption\":\"datakuuotlymybm\",\"partitionSettings\":{\"partitionColumnName\":\"datakxkmtuyn\",\"partitionUpperBound\":\"datap\",\"partitionLowerBound\":\"dataj\"},\"queryTimeout\":\"datasvfhqtqqshbip\",\"additionalColumns\":\"datauhujkz\",\"sourceRetryCount\":\"dataezgphipt\",\"sourceRetryWait\":\"dataqldnhwdfxgeccckk\",\"maxConcurrentConnections\":\"dataz\",\"disableMetricsCollection\":\"datas\",\"\":{\"pxdzmpjfbd\":\"datao\",\"iocqoydqyzhfny\":\"dataoawhbdxxnmyxz\",\"skt\":\"datagbwdsaqwywayjin\",\"ygyeyxmuwgn\":\"datarnknnql\"}}")
.toObject(SqlMISource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlMISource model = new SqlMISource().withSourceRetryCount("datahzxzazofr")
- .withSourceRetryWait("datasxjdgaimk")
- .withMaxConcurrentConnections("datasowszb")
- .withDisableMetricsCollection("datalhxik")
- .withQueryTimeout("datajbjjlxsv")
- .withAdditionalColumns("databggsnanojty")
- .withSqlReaderQuery("datarjmicha")
- .withSqlReaderStoredProcedureName("dataen")
- .withStoredProcedureParameters("dataqjvdde")
- .withIsolationLevel("datavrjhtpxydiuviup")
- .withProduceAdditionalTypes("datatnsyrrybdyqiv")
- .withPartitionOption("datasuhozihd")
- .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datajwthwcpijgasnafd")
- .withPartitionUpperBound("datanwgirnjgso")
- .withPartitionLowerBound("databdhrcepanhygca"));
+ SqlMISource model = new SqlMISource().withSourceRetryCount("dataezgphipt")
+ .withSourceRetryWait("dataqldnhwdfxgeccckk")
+ .withMaxConcurrentConnections("dataz")
+ .withDisableMetricsCollection("datas")
+ .withQueryTimeout("datasvfhqtqqshbip")
+ .withAdditionalColumns("datauhujkz")
+ .withSqlReaderQuery("datardtrdukdmsktuv")
+ .withSqlReaderStoredProcedureName("datazxtvytoyf")
+ .withStoredProcedureParameters("datagrzwdwdudxqeb")
+ .withIsolationLevel("datapsplwtlocseybv")
+ .withProduceAdditionalTypes("datacoznnjqxck")
+ .withPartitionOption("datakuuotlymybm")
+ .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datakxkmtuyn")
+ .withPartitionUpperBound("datap")
+ .withPartitionLowerBound("dataj"));
model = BinaryData.fromObject(model).toObject(SqlMISource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlPartitionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlPartitionSettingsTests.java
index 931f1a2aaaac..45601b0a15ba 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlPartitionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlPartitionSettingsTests.java
@@ -11,15 +11,15 @@ public final class SqlPartitionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlPartitionSettings model = BinaryData.fromString(
- "{\"partitionColumnName\":\"dataadafecwnufldzjc\",\"partitionUpperBound\":\"datahjbzpoh\",\"partitionLowerBound\":\"datajgpe\"}")
+ "{\"partitionColumnName\":\"dataqnwpwrfe\",\"partitionUpperBound\":\"dataggrm\",\"partitionLowerBound\":\"datafhkoe\"}")
.toObject(SqlPartitionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlPartitionSettings model = new SqlPartitionSettings().withPartitionColumnName("dataadafecwnufldzjc")
- .withPartitionUpperBound("datahjbzpoh")
- .withPartitionLowerBound("datajgpe");
+ SqlPartitionSettings model = new SqlPartitionSettings().withPartitionColumnName("dataqnwpwrfe")
+ .withPartitionUpperBound("dataggrm")
+ .withPartitionLowerBound("datafhkoe");
model = BinaryData.fromObject(model).toObject(SqlPartitionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerBaseLinkedServiceTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerBaseLinkedServiceTypePropertiesTests.java
index 5c579ea7f2d8..d235a4005e29 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerBaseLinkedServiceTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerBaseLinkedServiceTypePropertiesTests.java
@@ -11,32 +11,32 @@ public final class SqlServerBaseLinkedServiceTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlServerBaseLinkedServiceTypeProperties model = BinaryData.fromString(
- "{\"server\":\"datamadkbxuip\",\"database\":\"dataawxugpubeqk\",\"encrypt\":\"datazmuzgueuyg\",\"trustServerCertificate\":\"datahauhe\",\"hostNameInCertificate\":\"dataswe\",\"applicationIntent\":\"datagxxzxwrnqwdjvl\",\"connectTimeout\":\"datazxyylwsfxqcmej\",\"connectRetryCount\":\"datajcbciuagakmxg\",\"connectRetryInterval\":\"datamavllp\",\"loadBalanceTimeout\":\"dataguzsyfwamhm\",\"commandTimeout\":\"dataxxb\",\"integratedSecurity\":\"datagwnompvy\",\"failoverPartner\":\"datacnzcu\",\"maxPoolSize\":\"datasalbjf\",\"minPoolSize\":\"dataexqfzmhkridipwc\",\"multipleActiveResultSets\":\"datannmpifjqhjenb\",\"multiSubnetFailover\":\"datapfpllosadjffllr\",\"packetSize\":\"datag\",\"pooling\":\"datayeok\"}")
+ "{\"server\":\"dataerlbcetrvirdfsd\",\"database\":\"datap\",\"encrypt\":\"dataloopz\",\"trustServerCertificate\":\"dataegchtabhacjlf\",\"hostNameInCertificate\":\"datacklvvwvpfq\",\"applicationIntent\":\"datavzhmlnfvyhdhff\",\"connectTimeout\":\"datadmhawbxnlkmazhle\",\"connectRetryCount\":\"dataroksay\",\"connectRetryInterval\":\"datafzzipyqtmdhb\",\"loadBalanceTimeout\":\"datakgmwxzlphzu\",\"commandTimeout\":\"dataq\",\"integratedSecurity\":\"databejhxopehel\",\"failoverPartner\":\"dataykhdapxdiibj\",\"maxPoolSize\":\"datauekhh\",\"minPoolSize\":\"datahxhuhhnrmmfzfkh\",\"multipleActiveResultSets\":\"datazjf\",\"multiSubnetFailover\":\"datajhtvbskgciedlqv\",\"packetSize\":\"datatrlsmsr\",\"pooling\":\"datafgb\"}")
.toObject(SqlServerBaseLinkedServiceTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SqlServerBaseLinkedServiceTypeProperties model
- = new SqlServerBaseLinkedServiceTypeProperties().withServer("datamadkbxuip")
- .withDatabase("dataawxugpubeqk")
- .withEncrypt("datazmuzgueuyg")
- .withTrustServerCertificate("datahauhe")
- .withHostnameInCertificate("dataswe")
- .withApplicationIntent("datagxxzxwrnqwdjvl")
- .withConnectTimeout("datazxyylwsfxqcmej")
- .withConnectRetryCount("datajcbciuagakmxg")
- .withConnectRetryInterval("datamavllp")
- .withLoadBalanceTimeout("dataguzsyfwamhm")
- .withCommandTimeout("dataxxb")
- .withIntegratedSecurity("datagwnompvy")
- .withFailoverPartner("datacnzcu")
- .withMaxPoolSize("datasalbjf")
- .withMinPoolSize("dataexqfzmhkridipwc")
- .withMultipleActiveResultSets("datannmpifjqhjenb")
- .withMultiSubnetFailover("datapfpllosadjffllr")
- .withPacketSize("datag")
- .withPooling("datayeok");
+ = new SqlServerBaseLinkedServiceTypeProperties().withServer("dataerlbcetrvirdfsd")
+ .withDatabase("datap")
+ .withEncrypt("dataloopz")
+ .withTrustServerCertificate("dataegchtabhacjlf")
+ .withHostnameInCertificate("datacklvvwvpfq")
+ .withApplicationIntent("datavzhmlnfvyhdhff")
+ .withConnectTimeout("datadmhawbxnlkmazhle")
+ .withConnectRetryCount("dataroksay")
+ .withConnectRetryInterval("datafzzipyqtmdhb")
+ .withLoadBalanceTimeout("datakgmwxzlphzu")
+ .withCommandTimeout("dataq")
+ .withIntegratedSecurity("databejhxopehel")
+ .withFailoverPartner("dataykhdapxdiibj")
+ .withMaxPoolSize("datauekhh")
+ .withMinPoolSize("datahxhuhhnrmmfzfkh")
+ .withMultipleActiveResultSets("datazjf")
+ .withMultiSubnetFailover("datajhtvbskgciedlqv")
+ .withPacketSize("datatrlsmsr")
+ .withPooling("datafgb");
model = BinaryData.fromObject(model).toObject(SqlServerBaseLinkedServiceTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerSourceTests.java
index a3bc7a34d279..3bcf73a36662 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerSourceTests.java
@@ -12,27 +12,27 @@ public final class SqlServerSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlServerSource model = BinaryData.fromString(
- "{\"type\":\"SqlServerSource\",\"sqlReaderQuery\":\"databoxvwtlnv\",\"sqlReaderStoredProcedureName\":\"datahtujaqpkup\",\"storedProcedureParameters\":\"datacrjeypd\",\"isolationLevel\":\"datascxzsynbdrqirni\",\"produceAdditionalTypes\":\"dataothyeb\",\"partitionOption\":\"dataesovsvjxnso\",\"partitionSettings\":{\"partitionColumnName\":\"datal\",\"partitionUpperBound\":\"datahlyhgiisnfaxtob\",\"partitionLowerBound\":\"datafpyilojwc\"},\"queryTimeout\":\"datary\",\"additionalColumns\":\"dataauskishhm\",\"sourceRetryCount\":\"datapgrkd\",\"sourceRetryWait\":\"datazaunbwcqti\",\"maxConcurrentConnections\":\"datavzds\",\"disableMetricsCollection\":\"datajhjlploa\",\"\":{\"zujvhu\":\"datalrdkc\"}}")
+ "{\"type\":\"SqlServerSource\",\"sqlReaderQuery\":\"datarjmicha\",\"sqlReaderStoredProcedureName\":\"dataen\",\"storedProcedureParameters\":\"dataqjvdde\",\"isolationLevel\":\"datavrjhtpxydiuviup\",\"produceAdditionalTypes\":\"datatnsyrrybdyqiv\",\"partitionOption\":\"datasuhozihd\",\"partitionSettings\":{\"partitionColumnName\":\"datajwthwcpijgasnafd\",\"partitionUpperBound\":\"datanwgirnjgso\",\"partitionLowerBound\":\"databdhrcepanhygca\"},\"queryTimeout\":\"datajbjjlxsv\",\"additionalColumns\":\"databggsnanojty\",\"sourceRetryCount\":\"datahzxzazofr\",\"sourceRetryWait\":\"datasxjdgaimk\",\"maxConcurrentConnections\":\"datasowszb\",\"disableMetricsCollection\":\"datalhxik\",\"\":{\"tzjxgassmnatnp\":\"datakyngarwz\",\"gek\":\"datalueylqysgmiix\",\"hlgpe\":\"datawecbqtkdgin\",\"cqgqrsopq\":\"dataqqcceyowrwvbqv\"}}")
.toObject(SqlServerSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlServerSource model = new SqlServerSource().withSourceRetryCount("datapgrkd")
- .withSourceRetryWait("datazaunbwcqti")
- .withMaxConcurrentConnections("datavzds")
- .withDisableMetricsCollection("datajhjlploa")
- .withQueryTimeout("datary")
- .withAdditionalColumns("dataauskishhm")
- .withSqlReaderQuery("databoxvwtlnv")
- .withSqlReaderStoredProcedureName("datahtujaqpkup")
- .withStoredProcedureParameters("datacrjeypd")
- .withIsolationLevel("datascxzsynbdrqirni")
- .withProduceAdditionalTypes("dataothyeb")
- .withPartitionOption("dataesovsvjxnso")
- .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datal")
- .withPartitionUpperBound("datahlyhgiisnfaxtob")
- .withPartitionLowerBound("datafpyilojwc"));
+ SqlServerSource model = new SqlServerSource().withSourceRetryCount("datahzxzazofr")
+ .withSourceRetryWait("datasxjdgaimk")
+ .withMaxConcurrentConnections("datasowszb")
+ .withDisableMetricsCollection("datalhxik")
+ .withQueryTimeout("datajbjjlxsv")
+ .withAdditionalColumns("databggsnanojty")
+ .withSqlReaderQuery("datarjmicha")
+ .withSqlReaderStoredProcedureName("dataen")
+ .withStoredProcedureParameters("dataqjvdde")
+ .withIsolationLevel("datavrjhtpxydiuviup")
+ .withProduceAdditionalTypes("datatnsyrrybdyqiv")
+ .withPartitionOption("datasuhozihd")
+ .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datajwthwcpijgasnafd")
+ .withPartitionUpperBound("datanwgirnjgso")
+ .withPartitionLowerBound("databdhrcepanhygca"));
model = BinaryData.fromObject(model).toObject(SqlServerSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTests.java
index f75b0f84c978..49e0fe07bd8a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTests.java
@@ -22,62 +22,54 @@ public final class SqlServerStoredProcedureActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlServerStoredProcedureActivity model = BinaryData.fromString(
- "{\"type\":\"SqlServerStoredProcedure\",\"typeProperties\":{\"storedProcedureName\":\"datapaiat\",\"storedProcedureParameters\":\"dataxvbwsa\"},\"linkedServiceName\":{\"referenceName\":\"vtinro\",\"parameters\":{\"pyh\":\"datatylseu\",\"n\":\"datanngijnzlokxihf\",\"ssxid\":\"databljlrfwq\"}},\"policy\":{\"timeout\":\"datavbicdzvypfo\",\"retry\":\"dataxbfctqnq\",\"retryIntervalInSeconds\":1638131634,\"secureInput\":false,\"secureOutput\":true,\"\":{\"q\":\"datakmjqfachfm\",\"qeu\":\"datakgs\",\"f\":\"datajvs\"}},\"name\":\"wpqvgxpwmoefhbur\",\"description\":\"a\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"wpxvptqnqbd\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"juuwmcugveiiegoo\":\"datazlfhn\",\"dfqthohfqbeai\":\"datablvcalb\",\"gdascmf\":\"datavnnhxgiydk\",\"xgy\":\"datakabwpdvedmxckb\"}},{\"activity\":\"xszetaonkfbgwf\",\"dependencyConditions\":[\"Succeeded\",\"Failed\",\"Skipped\"],\"\":{\"j\":\"datazrsz\",\"udnxaw\":\"datadcisceiauoy\",\"cc\":\"datagmbmb\"}},{\"activity\":\"ikp\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"o\":\"datajizbjsu\"}}],\"userProperties\":[{\"name\":\"ltcrtmebrssrlxen\",\"value\":\"datapthc\"},{\"name\":\"j\",\"value\":\"dataqmb\"},{\"name\":\"xensog\",\"value\":\"datavhqqxggncgyzvt\"},{\"name\":\"excjqrvpgukscrsb\",\"value\":\"datahkdemaxoaj\"}],\"\":{\"ajkkzkzprjqbmgf\":\"datacachsojgagey\",\"zbeemlsrtgbgcmut\":\"datawy\",\"lpuuf\":\"datakwd\"}}")
+ "{\"type\":\"SqlServerStoredProcedure\",\"typeProperties\":{\"storedProcedureName\":\"datamfbl\",\"storedProcedureParameters\":\"dataekoux\"},\"linkedServiceName\":{\"referenceName\":\"lif\",\"parameters\":{\"foibxj\":\"datad\",\"zlq\":\"datacuppwsgawqxren\"}},\"policy\":{\"timeout\":\"dataft\",\"retry\":\"datapzhox\",\"retryIntervalInSeconds\":1278696212,\"secureInput\":false,\"secureOutput\":true,\"\":{\"ypara\":\"datavtefevhedfzxs\",\"rlbsglqiuqsqzumx\":\"datargsfnjokrfpiqgqv\",\"muosoziqcuiekuya\":\"datax\",\"dxmdpfxlkwyqo\":\"datapukxtgeejxwbr\"}},\"name\":\"ejylqgenbeupaiat\",\"description\":\"xvbwsa\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"ortjtylseudpyhvn\",\"dependencyConditions\":[\"Failed\"],\"\":{\"n\":\"datazlokxihf\",\"ssxid\":\"databljlrfwq\"}}],\"userProperties\":[{\"name\":\"vbicdzvypfo\",\"value\":\"datazxbf\"},{\"name\":\"tqnq\",\"value\":\"datalmqeauizk\"},{\"name\":\"jqfachfmvqnkgst\",\"value\":\"datae\"},{\"name\":\"ujvsc\",\"value\":\"datapwpqvg\"}],\"\":{\"tv\":\"datamoefhburxnagvcs\",\"bdxwy\":\"datapxvptqn\",\"iiegoolblvcalbud\":\"datatzlfhnfjuuwmcugv\"}}")
.toObject(SqlServerStoredProcedureActivity.class);
- Assertions.assertEquals("wpqvgxpwmoefhbur", model.name());
- Assertions.assertEquals("a", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("wpxvptqnqbd", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("ltcrtmebrssrlxen", model.userProperties().get(0).name());
- Assertions.assertEquals("vtinro", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1638131634, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("ejylqgenbeupaiat", model.name());
+ Assertions.assertEquals("xvbwsa", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
+ Assertions.assertEquals("ortjtylseudpyhvn", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("vbicdzvypfo", model.userProperties().get(0).name());
+ Assertions.assertEquals("lif", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1278696212, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlServerStoredProcedureActivity model = new SqlServerStoredProcedureActivity().withName("wpqvgxpwmoefhbur")
- .withDescription("a")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("wpxvptqnqbd")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("xszetaonkfbgwf")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED,
- DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ikp")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("ltcrtmebrssrlxen").withValue("datapthc"),
- new UserProperty().withName("j").withValue("dataqmb"),
- new UserProperty().withName("xensog").withValue("datavhqqxggncgyzvt"),
- new UserProperty().withName("excjqrvpgukscrsb").withValue("datahkdemaxoaj")))
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("vtinro")
- .withParameters(mapOf("pyh", "datatylseu", "n", "datanngijnzlokxihf", "ssxid", "databljlrfwq")))
- .withPolicy(new ActivityPolicy().withTimeout("datavbicdzvypfo")
- .withRetry("dataxbfctqnq")
- .withRetryIntervalInSeconds(1638131634)
+ SqlServerStoredProcedureActivity model = new SqlServerStoredProcedureActivity().withName("ejylqgenbeupaiat")
+ .withDescription("xvbwsa")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("ortjtylseudpyhvn")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("vbicdzvypfo").withValue("datazxbf"),
+ new UserProperty().withName("tqnq").withValue("datalmqeauizk"),
+ new UserProperty().withName("jqfachfmvqnkgst").withValue("datae"),
+ new UserProperty().withName("ujvsc").withValue("datapwpqvg")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lif")
+ .withParameters(mapOf("foibxj", "datad", "zlq", "datacuppwsgawqxren")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataft")
+ .withRetry("datapzhox")
+ .withRetryIntervalInSeconds(1278696212)
.withSecureInput(false)
.withSecureOutput(true)
.withAdditionalProperties(mapOf()))
- .withStoredProcedureName("datapaiat")
- .withStoredProcedureParameters("dataxvbwsa");
+ .withStoredProcedureName("datamfbl")
+ .withStoredProcedureParameters("dataekoux");
model = BinaryData.fromObject(model).toObject(SqlServerStoredProcedureActivity.class);
- Assertions.assertEquals("wpqvgxpwmoefhbur", model.name());
- Assertions.assertEquals("a", model.description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("wpxvptqnqbd", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("ltcrtmebrssrlxen", model.userProperties().get(0).name());
- Assertions.assertEquals("vtinro", model.linkedServiceName().referenceName());
- Assertions.assertEquals(1638131634, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals("ejylqgenbeupaiat", model.name());
+ Assertions.assertEquals("xvbwsa", model.description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
+ Assertions.assertEquals("ortjtylseudpyhvn", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("vbicdzvypfo", model.userProperties().get(0).name());
+ Assertions.assertEquals("lif", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(1278696212, model.policy().retryIntervalInSeconds());
Assertions.assertEquals(false, model.policy().secureInput());
Assertions.assertEquals(true, model.policy().secureOutput());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTypePropertiesTests.java
index 043290335a70..c3e626f36997 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerStoredProcedureActivityTypePropertiesTests.java
@@ -10,16 +10,16 @@
public final class SqlServerStoredProcedureActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SqlServerStoredProcedureActivityTypeProperties model
- = BinaryData.fromString("{\"storedProcedureName\":\"datahbdmmf\",\"storedProcedureParameters\":\"datax\"}")
- .toObject(SqlServerStoredProcedureActivityTypeProperties.class);
+ SqlServerStoredProcedureActivityTypeProperties model = BinaryData
+ .fromString("{\"storedProcedureName\":\"dataqthohfqbeaizv\",\"storedProcedureParameters\":\"datahxgiy\"}")
+ .toObject(SqlServerStoredProcedureActivityTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SqlServerStoredProcedureActivityTypeProperties model
- = new SqlServerStoredProcedureActivityTypeProperties().withStoredProcedureName("datahbdmmf")
- .withStoredProcedureParameters("datax");
+ = new SqlServerStoredProcedureActivityTypeProperties().withStoredProcedureName("dataqthohfqbeaizv")
+ .withStoredProcedureParameters("datahxgiy");
model = BinaryData.fromObject(model).toObject(SqlServerStoredProcedureActivityTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTests.java
index eda845a17558..4395792416c3 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTests.java
@@ -19,37 +19,35 @@ public final class SqlServerTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlServerTableDataset model = BinaryData.fromString(
- "{\"type\":\"SqlServerTable\",\"typeProperties\":{\"tableName\":\"dataszfutgpbygbnbc\",\"schema\":\"dataiqgtzpv\",\"table\":\"datawfl\"},\"description\":\"hxzuxerxhyw\",\"structure\":\"datakqsqvvdkfp\",\"schema\":\"datadajdqxymxxyfr\",\"linkedServiceName\":{\"referenceName\":\"j\",\"parameters\":{\"ld\":\"dataetfvgwfw\",\"rsnxfrp\":\"datagwouppvyddqsvc\",\"xzxlcqzfxa\":\"datawwqclmdmtfxxepz\"}},\"parameters\":{\"smkir\":{\"type\":\"SecureString\",\"defaultValue\":\"datacj\"},\"hkcomeobw\":{\"type\":\"Bool\",\"defaultValue\":\"dataipud\"}},\"annotations\":[\"datazltenlbfxl\",\"dataxozesn\"],\"folder\":{\"name\":\"uomtxj\"},\"\":{\"wis\":\"dataxymckikkqyvur\",\"ktehognsdd\":\"datayfmrzcqfevnkyak\"}}")
+ "{\"type\":\"SqlServerTable\",\"typeProperties\":{\"tableName\":\"datav\",\"schema\":\"datadfkhttuobrxz\",\"table\":\"dataytebjkjge\"},\"description\":\"wtfma\",\"structure\":\"databmnhtwofx\",\"schema\":\"datahlvyqns\",\"linkedServiceName\":{\"referenceName\":\"bq\",\"parameters\":{\"hj\":\"dataqkie\",\"spt\":\"dataqqrugwespscvs\",\"supcvqgxcvw\":\"datauwozfvz\",\"cmcgmlmpnvq\":\"dataoq\"}},\"parameters\":{\"dqseypdlmajpuy\":{\"type\":\"Bool\",\"defaultValue\":\"datarzn\"},\"mzgccy\":{\"type\":\"String\",\"defaultValue\":\"dataf\"}},\"annotations\":[\"datavmsiehedm\",\"datavoneey\"],\"folder\":{\"name\":\"a\"},\"\":{\"qwddigebls\":\"dataza\",\"wveeozbjkj\":\"datalzdssi\"}}")
.toObject(SqlServerTableDataset.class);
- Assertions.assertEquals("hxzuxerxhyw", model.description());
- Assertions.assertEquals("j", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("smkir").type());
- Assertions.assertEquals("uomtxj", model.folder().name());
+ Assertions.assertEquals("wtfma", model.description());
+ Assertions.assertEquals("bq", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("dqseypdlmajpuy").type());
+ Assertions.assertEquals("a", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlServerTableDataset model
- = new SqlServerTableDataset().withDescription("hxzuxerxhyw")
- .withStructure("datakqsqvvdkfp")
- .withSchema("datadajdqxymxxyfr")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("j")
- .withParameters(mapOf("ld", "dataetfvgwfw", "rsnxfrp", "datagwouppvyddqsvc", "xzxlcqzfxa",
- "datawwqclmdmtfxxepz")))
- .withParameters(mapOf("smkir",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datacj"),
- "hkcomeobw",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataipud")))
- .withAnnotations(Arrays.asList("datazltenlbfxl", "dataxozesn"))
- .withFolder(new DatasetFolder().withName("uomtxj"))
- .withTableName("dataszfutgpbygbnbc")
- .withSchemaTypePropertiesSchema("dataiqgtzpv")
- .withTable("datawfl");
+ SqlServerTableDataset model = new SqlServerTableDataset().withDescription("wtfma")
+ .withStructure("databmnhtwofx")
+ .withSchema("datahlvyqns")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("bq")
+ .withParameters(mapOf("hj", "dataqkie", "spt", "dataqqrugwespscvs", "supcvqgxcvw", "datauwozfvz",
+ "cmcgmlmpnvq", "dataoq")))
+ .withParameters(mapOf("dqseypdlmajpuy",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datarzn"), "mzgccy",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataf")))
+ .withAnnotations(Arrays.asList("datavmsiehedm", "datavoneey"))
+ .withFolder(new DatasetFolder().withName("a"))
+ .withTableName("datav")
+ .withSchemaTypePropertiesSchema("datadfkhttuobrxz")
+ .withTable("dataytebjkjge");
model = BinaryData.fromObject(model).toObject(SqlServerTableDataset.class);
- Assertions.assertEquals("hxzuxerxhyw", model.description());
- Assertions.assertEquals("j", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("smkir").type());
- Assertions.assertEquals("uomtxj", model.folder().name());
+ Assertions.assertEquals("wtfma", model.description());
+ Assertions.assertEquals("bq", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("dqseypdlmajpuy").type());
+ Assertions.assertEquals("a", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTypePropertiesTests.java
index 654e54d446c2..23b8e6720883 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlServerTableDatasetTypePropertiesTests.java
@@ -10,16 +10,17 @@
public final class SqlServerTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SqlServerTableDatasetTypeProperties model
- = BinaryData.fromString("{\"tableName\":\"datakde\",\"schema\":\"datasuaz\",\"table\":\"datafcnxc\"}")
- .toObject(SqlServerTableDatasetTypeProperties.class);
+ SqlServerTableDatasetTypeProperties model = BinaryData
+ .fromString("{\"tableName\":\"dataizdnuehx\",\"schema\":\"datatssjd\",\"table\":\"databnklgerxac\"}")
+ .toObject(SqlServerTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlServerTableDatasetTypeProperties model = new SqlServerTableDatasetTypeProperties().withTableName("datakde")
- .withSchema("datasuaz")
- .withTable("datafcnxc");
+ SqlServerTableDatasetTypeProperties model
+ = new SqlServerTableDatasetTypeProperties().withTableName("dataizdnuehx")
+ .withSchema("datatssjd")
+ .withTable("databnklgerxac");
model = BinaryData.fromObject(model).toObject(SqlServerTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlSourceTests.java
index 6561b6ece0af..42148bf077ed 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SqlSourceTests.java
@@ -12,26 +12,26 @@ public final class SqlSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SqlSource model = BinaryData.fromString(
- "{\"type\":\"SqlSource\",\"sqlReaderQuery\":\"dataokqeuzslny\",\"sqlReaderStoredProcedureName\":\"datauywijnlpeczq\",\"storedProcedureParameters\":\"datamzkqydthf\",\"isolationLevel\":\"dataycmwvphrwuf\",\"partitionOption\":\"dataov\",\"partitionSettings\":{\"partitionColumnName\":\"datasqlekchjdh\",\"partitionUpperBound\":\"datakeif\",\"partitionLowerBound\":\"datatcownxiw\"},\"queryTimeout\":\"datatvbudbnu\",\"additionalColumns\":\"datamllyjelnhm\",\"sourceRetryCount\":\"datahxkofzxkqsle\",\"sourceRetryWait\":\"databam\",\"maxConcurrentConnections\":\"datanwgccgblepam\",\"disableMetricsCollection\":\"databaxdaoja\",\"\":{\"ljmj\":\"dataoxwqlnxvnm\"}}")
+ "{\"type\":\"SqlSource\",\"sqlReaderQuery\":\"dataiob\",\"sqlReaderStoredProcedureName\":\"datatpyemppwkry\",\"storedProcedureParameters\":\"datadqpkqf\",\"isolationLevel\":\"datahoiq\",\"partitionOption\":\"databhmy\",\"partitionSettings\":{\"partitionColumnName\":\"datamfyernc\",\"partitionUpperBound\":\"datagwiquka\",\"partitionLowerBound\":\"dataokeolzizfbunzm\"},\"queryTimeout\":\"datafttmjomuwl\",\"additionalColumns\":\"datajwkpznsfbi\",\"sourceRetryCount\":\"datafzgpvdlx\",\"sourceRetryWait\":\"dataotclcuxzllnwmgqc\",\"maxConcurrentConnections\":\"datagjequox\",\"disableMetricsCollection\":\"datagfspwhfhdguuvg\",\"\":{\"ytqzx\":\"datazvd\"}}")
.toObject(SqlSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SqlSource model = new SqlSource().withSourceRetryCount("datahxkofzxkqsle")
- .withSourceRetryWait("databam")
- .withMaxConcurrentConnections("datanwgccgblepam")
- .withDisableMetricsCollection("databaxdaoja")
- .withQueryTimeout("datatvbudbnu")
- .withAdditionalColumns("datamllyjelnhm")
- .withSqlReaderQuery("dataokqeuzslny")
- .withSqlReaderStoredProcedureName("datauywijnlpeczq")
- .withStoredProcedureParameters("datamzkqydthf")
- .withIsolationLevel("dataycmwvphrwuf")
- .withPartitionOption("dataov")
- .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datasqlekchjdh")
- .withPartitionUpperBound("datakeif")
- .withPartitionLowerBound("datatcownxiw"));
+ SqlSource model = new SqlSource().withSourceRetryCount("datafzgpvdlx")
+ .withSourceRetryWait("dataotclcuxzllnwmgqc")
+ .withMaxConcurrentConnections("datagjequox")
+ .withDisableMetricsCollection("datagfspwhfhdguuvg")
+ .withQueryTimeout("datafttmjomuwl")
+ .withAdditionalColumns("datajwkpznsfbi")
+ .withSqlReaderQuery("dataiob")
+ .withSqlReaderStoredProcedureName("datatpyemppwkry")
+ .withStoredProcedureParameters("datadqpkqf")
+ .withIsolationLevel("datahoiq")
+ .withPartitionOption("databhmy")
+ .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datamfyernc")
+ .withPartitionUpperBound("datagwiquka")
+ .withPartitionLowerBound("dataokeolzizfbunzm"));
model = BinaryData.fromObject(model).toObject(SqlSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareObjectDatasetTests.java
index 27bd26d28de6..9af996d1bbc2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareObjectDatasetTests.java
@@ -19,31 +19,36 @@ public final class SquareObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SquareObjectDataset model = BinaryData.fromString(
- "{\"type\":\"SquareObject\",\"typeProperties\":{\"tableName\":\"dataktdutydvvgkmo\"},\"description\":\"pcjes\",\"structure\":\"datavuztnsvmsh\",\"schema\":\"datagygfohrm\",\"linkedServiceName\":{\"referenceName\":\"hhlclpkr\",\"parameters\":{\"utivrfnztxtmrm\":\"databmjjv\",\"ii\":\"dataftj\",\"hfh\":\"dataohlgrjcx\"}},\"parameters\":{\"ylyumb\":{\"type\":\"Object\",\"defaultValue\":\"datawfogbv\"}},\"annotations\":[\"datarlnuom\",\"dataxhdkhmemx\"],\"folder\":{\"name\":\"apesnbyoullyfz\"},\"\":{\"g\":\"datarmxxjvwbat\",\"ommdzphxulx\":\"datakmwfwzlmpxfmdjs\"}}")
+ "{\"type\":\"SquareObject\",\"typeProperties\":{\"tableName\":\"dataheexzhhllxwk\"},\"description\":\"oxdjklf\",\"structure\":\"datantk\",\"schema\":\"datay\",\"linkedServiceName\":{\"referenceName\":\"mddslwnlgjdlh\",\"parameters\":{\"s\":\"datapybnnnlpqdn\",\"jerndzzywxqraqx\":\"dataatupmrslwknrdvvm\",\"putl\":\"datakdeetnne\"}},\"parameters\":{\"sxwasfwqjz\":{\"type\":\"Array\",\"defaultValue\":\"datajmr\"},\"cfguam\":{\"type\":\"Int\",\"defaultValue\":\"datafqdnpp\"},\"blukgctvnspjvsy\":{\"type\":\"Array\",\"defaultValue\":\"datamuvkgdwpj\"}},\"annotations\":[\"datalhdukcsqvyeegx\",\"dataulojwumfjdymeq\",\"datanxpfyxdjspnonx\"],\"folder\":{\"name\":\"qpzhna\"},\"\":{\"evtwll\":\"datagcmcvdjlwwe\"}}")
.toObject(SquareObjectDataset.class);
- Assertions.assertEquals("pcjes", model.description());
- Assertions.assertEquals("hhlclpkr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("ylyumb").type());
- Assertions.assertEquals("apesnbyoullyfz", model.folder().name());
+ Assertions.assertEquals("oxdjklf", model.description());
+ Assertions.assertEquals("mddslwnlgjdlh", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("sxwasfwqjz").type());
+ Assertions.assertEquals("qpzhna", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SquareObjectDataset model = new SquareObjectDataset().withDescription("pcjes")
- .withStructure("datavuztnsvmsh")
- .withSchema("datagygfohrm")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("hhlclpkr")
- .withParameters(mapOf("utivrfnztxtmrm", "databmjjv", "ii", "dataftj", "hfh", "dataohlgrjcx")))
- .withParameters(mapOf("ylyumb",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datawfogbv")))
- .withAnnotations(Arrays.asList("datarlnuom", "dataxhdkhmemx"))
- .withFolder(new DatasetFolder().withName("apesnbyoullyfz"))
- .withTableName("dataktdutydvvgkmo");
+ SquareObjectDataset model
+ = new SquareObjectDataset().withDescription("oxdjklf")
+ .withStructure("datantk")
+ .withSchema("datay")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("mddslwnlgjdlh")
+ .withParameters(mapOf("s", "datapybnnnlpqdn", "jerndzzywxqraqx", "dataatupmrslwknrdvvm", "putl",
+ "datakdeetnne")))
+ .withParameters(mapOf("sxwasfwqjz",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datajmr"), "cfguam",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datafqdnpp"),
+ "blukgctvnspjvsy",
+ new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datamuvkgdwpj")))
+ .withAnnotations(Arrays.asList("datalhdukcsqvyeegx", "dataulojwumfjdymeq", "datanxpfyxdjspnonx"))
+ .withFolder(new DatasetFolder().withName("qpzhna"))
+ .withTableName("dataheexzhhllxwk");
model = BinaryData.fromObject(model).toObject(SquareObjectDataset.class);
- Assertions.assertEquals("pcjes", model.description());
- Assertions.assertEquals("hhlclpkr", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("ylyumb").type());
- Assertions.assertEquals("apesnbyoullyfz", model.folder().name());
+ Assertions.assertEquals("oxdjklf", model.description());
+ Assertions.assertEquals("mddslwnlgjdlh", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("sxwasfwqjz").type());
+ Assertions.assertEquals("qpzhna", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareSourceTests.java
index 1bc159f2b649..8904ed1dde7e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SquareSourceTests.java
@@ -11,19 +11,19 @@ public final class SquareSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SquareSource model = BinaryData.fromString(
- "{\"type\":\"SquareSource\",\"query\":\"datayddijfkktigisee\",\"queryTimeout\":\"datazrerxyds\",\"additionalColumns\":\"datapn\",\"sourceRetryCount\":\"dataarkjt\",\"sourceRetryWait\":\"dataaczkjkfakgrwt\",\"maxConcurrentConnections\":\"datasfanmjmpce\",\"disableMetricsCollection\":\"datamfdylvpyhhgqysz\",\"\":{\"jekolnylpyk\":\"datajzhvej\",\"aouyaanfxai\":\"datapa\"}}")
+ "{\"type\":\"SquareSource\",\"query\":\"dataxnepub\",\"queryTimeout\":\"datainfauytmqvsdyqyj\",\"additionalColumns\":\"datafotwmxedlcxmyxt\",\"sourceRetryCount\":\"dataapoj\",\"sourceRetryWait\":\"datavxan\",\"maxConcurrentConnections\":\"datapspiipfgdn\",\"disableMetricsCollection\":\"datakvvrhoqy\",\"\":{\"xhskhkqlvocrdd\":\"datavnruodu\"}}")
.toObject(SquareSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SquareSource model = new SquareSource().withSourceRetryCount("dataarkjt")
- .withSourceRetryWait("dataaczkjkfakgrwt")
- .withMaxConcurrentConnections("datasfanmjmpce")
- .withDisableMetricsCollection("datamfdylvpyhhgqysz")
- .withQueryTimeout("datazrerxyds")
- .withAdditionalColumns("datapn")
- .withQuery("datayddijfkktigisee");
+ SquareSource model = new SquareSource().withSourceRetryCount("dataapoj")
+ .withSourceRetryWait("datavxan")
+ .withMaxConcurrentConnections("datapspiipfgdn")
+ .withDisableMetricsCollection("datakvvrhoqy")
+ .withQueryTimeout("datainfauytmqvsdyqyj")
+ .withAdditionalColumns("datafotwmxedlcxmyxt")
+ .withQuery("dataxnepub");
model = BinaryData.fromObject(model).toObject(SquareSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisChildPackageTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisChildPackageTests.java
index 341431e74c76..42c02539672f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisChildPackageTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisChildPackageTests.java
@@ -12,20 +12,20 @@ public final class SsisChildPackageTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisChildPackage model = BinaryData.fromString(
- "{\"packagePath\":\"dataooqobpnkvn\",\"packageName\":\"jrxbbxkh\",\"packageContent\":\"dataeqbxvtgloifmlbh\",\"packageLastModifiedDate\":\"mgzimtzzy\"}")
+ "{\"packagePath\":\"dataykatjsebcuynqdli\",\"packageName\":\"e\",\"packageContent\":\"datadvjgbemrjbo\",\"packageLastModifiedDate\":\"uxpdp\"}")
.toObject(SsisChildPackage.class);
- Assertions.assertEquals("jrxbbxkh", model.packageName());
- Assertions.assertEquals("mgzimtzzy", model.packageLastModifiedDate());
+ Assertions.assertEquals("e", model.packageName());
+ Assertions.assertEquals("uxpdp", model.packageLastModifiedDate());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisChildPackage model = new SsisChildPackage().withPackagePath("dataooqobpnkvn")
- .withPackageName("jrxbbxkh")
- .withPackageContent("dataeqbxvtgloifmlbh")
- .withPackageLastModifiedDate("mgzimtzzy");
+ SsisChildPackage model = new SsisChildPackage().withPackagePath("dataykatjsebcuynqdli")
+ .withPackageName("e")
+ .withPackageContent("datadvjgbemrjbo")
+ .withPackageLastModifiedDate("uxpdp");
model = BinaryData.fromObject(model).toObject(SsisChildPackage.class);
- Assertions.assertEquals("jrxbbxkh", model.packageName());
- Assertions.assertEquals("mgzimtzzy", model.packageLastModifiedDate());
+ Assertions.assertEquals("e", model.packageName());
+ Assertions.assertEquals("uxpdp", model.packageLastModifiedDate());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentReferenceTests.java
index 9086170e1434..88c2d60a67dd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentReferenceTests.java
@@ -12,24 +12,24 @@ public final class SsisEnvironmentReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisEnvironmentReference model = BinaryData.fromString(
- "{\"id\":4735945091995034165,\"environmentFolderName\":\"hyrn\",\"environmentName\":\"jrgfbmpszwkbcstz\",\"referenceType\":\"bgaesm\"}")
+ "{\"id\":8066126352512249391,\"environmentFolderName\":\"vofuyzvbploazc\",\"environmentName\":\"hgermm\",\"referenceType\":\"kbxui\"}")
.toObject(SsisEnvironmentReference.class);
- Assertions.assertEquals(4735945091995034165L, model.id());
- Assertions.assertEquals("hyrn", model.environmentFolderName());
- Assertions.assertEquals("jrgfbmpszwkbcstz", model.environmentName());
- Assertions.assertEquals("bgaesm", model.referenceType());
+ Assertions.assertEquals(8066126352512249391L, model.id());
+ Assertions.assertEquals("vofuyzvbploazc", model.environmentFolderName());
+ Assertions.assertEquals("hgermm", model.environmentName());
+ Assertions.assertEquals("kbxui", model.referenceType());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisEnvironmentReference model = new SsisEnvironmentReference().withId(4735945091995034165L)
- .withEnvironmentFolderName("hyrn")
- .withEnvironmentName("jrgfbmpszwkbcstz")
- .withReferenceType("bgaesm");
+ SsisEnvironmentReference model = new SsisEnvironmentReference().withId(8066126352512249391L)
+ .withEnvironmentFolderName("vofuyzvbploazc")
+ .withEnvironmentName("hgermm")
+ .withReferenceType("kbxui");
model = BinaryData.fromObject(model).toObject(SsisEnvironmentReference.class);
- Assertions.assertEquals(4735945091995034165L, model.id());
- Assertions.assertEquals("hyrn", model.environmentFolderName());
- Assertions.assertEquals("jrgfbmpszwkbcstz", model.environmentName());
- Assertions.assertEquals("bgaesm", model.referenceType());
+ Assertions.assertEquals(8066126352512249391L, model.id());
+ Assertions.assertEquals("vofuyzvbploazc", model.environmentFolderName());
+ Assertions.assertEquals("hgermm", model.environmentName());
+ Assertions.assertEquals("kbxui", model.referenceType());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentTests.java
index 7a9a8f050006..69957007bbe0 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisEnvironmentTests.java
@@ -14,60 +14,67 @@ public final class SsisEnvironmentTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisEnvironment model = BinaryData.fromString(
- "{\"type\":\"Environment\",\"folderId\":8944070795440540678,\"variables\":[{\"id\":8456784201907262272,\"name\":\"nwnlcfzfjdzkfth\",\"description\":\"dphdb\",\"dataType\":\"etfgkzqbvh\",\"sensitive\":false,\"value\":\"ymkgjsry\",\"sensitiveValue\":\"f\"},{\"id\":1063195116593218900,\"name\":\"pftkgmbmvxbiubz\",\"description\":\"psotbame\",\"dataType\":\"busnaq\",\"sensitive\":false,\"value\":\"uhyncppmmwhje\",\"sensitiveValue\":\"urgipv\"},{\"id\":9204988078857470987,\"name\":\"psmckgpxd\",\"description\":\"cqmguvdk\",\"dataType\":\"ihrfcowla\",\"sensitive\":true,\"value\":\"fywxjjylaqhxevf\",\"sensitiveValue\":\"rvjhwgkynxlwrj\"}],\"id\":1315044173320403578,\"name\":\"mcktkal\",\"description\":\"i\"}")
+ "{\"type\":\"Environment\",\"folderId\":6305964571481835052,\"variables\":[{\"id\":8018758763891691267,\"name\":\"mny\",\"description\":\"tgslkokq\",\"dataType\":\"gzcojgdq\",\"sensitive\":true,\"value\":\"ecjgpjnydkkgbv\",\"sensitiveValue\":\"ks\"},{\"id\":8051176005880059497,\"name\":\"avnr\",\"description\":\"qqiwfysuj\",\"dataType\":\"hclgpexrxyrpwzsm\",\"sensitive\":false,\"value\":\"p\",\"sensitiveValue\":\"bpcifdv\"},{\"id\":4825989979528086841,\"name\":\"nfnyjwjmy\",\"description\":\"htmlgjaick\",\"dataType\":\"jdwi\",\"sensitive\":true,\"value\":\"ibjgvmkawuu\",\"sensitiveValue\":\"zfhurrw\"},{\"id\":3338369916044561912,\"name\":\"tzmxxi\",\"description\":\"ehyl\",\"dataType\":\"ayypsxyhoemsdn\",\"sensitive\":true,\"value\":\"opvfg\",\"sensitiveValue\":\"rxumwdqwy\"}],\"id\":5882503334253851296,\"name\":\"eleqpnk\",\"description\":\"krum\"}")
.toObject(SsisEnvironment.class);
- Assertions.assertEquals(1315044173320403578L, model.id());
- Assertions.assertEquals("mcktkal", model.name());
- Assertions.assertEquals("i", model.description());
- Assertions.assertEquals(8944070795440540678L, model.folderId());
- Assertions.assertEquals(8456784201907262272L, model.variables().get(0).id());
- Assertions.assertEquals("nwnlcfzfjdzkfth", model.variables().get(0).name());
- Assertions.assertEquals("dphdb", model.variables().get(0).description());
- Assertions.assertEquals("etfgkzqbvh", model.variables().get(0).dataType());
- Assertions.assertEquals(false, model.variables().get(0).sensitive());
- Assertions.assertEquals("ymkgjsry", model.variables().get(0).value());
- Assertions.assertEquals("f", model.variables().get(0).sensitiveValue());
+ Assertions.assertEquals(5882503334253851296L, model.id());
+ Assertions.assertEquals("eleqpnk", model.name());
+ Assertions.assertEquals("krum", model.description());
+ Assertions.assertEquals(6305964571481835052L, model.folderId());
+ Assertions.assertEquals(8018758763891691267L, model.variables().get(0).id());
+ Assertions.assertEquals("mny", model.variables().get(0).name());
+ Assertions.assertEquals("tgslkokq", model.variables().get(0).description());
+ Assertions.assertEquals("gzcojgdq", model.variables().get(0).dataType());
+ Assertions.assertEquals(true, model.variables().get(0).sensitive());
+ Assertions.assertEquals("ecjgpjnydkkgbv", model.variables().get(0).value());
+ Assertions.assertEquals("ks", model.variables().get(0).sensitiveValue());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisEnvironment model = new SsisEnvironment().withId(1315044173320403578L)
- .withName("mcktkal")
- .withDescription("i")
- .withFolderId(8944070795440540678L)
+ SsisEnvironment model = new SsisEnvironment().withId(5882503334253851296L)
+ .withName("eleqpnk")
+ .withDescription("krum")
+ .withFolderId(6305964571481835052L)
.withVariables(Arrays.asList(
- new SsisVariable().withId(8456784201907262272L)
- .withName("nwnlcfzfjdzkfth")
- .withDescription("dphdb")
- .withDataType("etfgkzqbvh")
- .withSensitive(false)
- .withValue("ymkgjsry")
- .withSensitiveValue("f"),
- new SsisVariable().withId(1063195116593218900L)
- .withName("pftkgmbmvxbiubz")
- .withDescription("psotbame")
- .withDataType("busnaq")
+ new SsisVariable().withId(8018758763891691267L)
+ .withName("mny")
+ .withDescription("tgslkokq")
+ .withDataType("gzcojgdq")
+ .withSensitive(true)
+ .withValue("ecjgpjnydkkgbv")
+ .withSensitiveValue("ks"),
+ new SsisVariable().withId(8051176005880059497L)
+ .withName("avnr")
+ .withDescription("qqiwfysuj")
+ .withDataType("hclgpexrxyrpwzsm")
.withSensitive(false)
- .withValue("uhyncppmmwhje")
- .withSensitiveValue("urgipv"),
- new SsisVariable().withId(9204988078857470987L)
- .withName("psmckgpxd")
- .withDescription("cqmguvdk")
- .withDataType("ihrfcowla")
+ .withValue("p")
+ .withSensitiveValue("bpcifdv"),
+ new SsisVariable().withId(4825989979528086841L)
+ .withName("nfnyjwjmy")
+ .withDescription("htmlgjaick")
+ .withDataType("jdwi")
+ .withSensitive(true)
+ .withValue("ibjgvmkawuu")
+ .withSensitiveValue("zfhurrw"),
+ new SsisVariable().withId(3338369916044561912L)
+ .withName("tzmxxi")
+ .withDescription("ehyl")
+ .withDataType("ayypsxyhoemsdn")
.withSensitive(true)
- .withValue("fywxjjylaqhxevf")
- .withSensitiveValue("rvjhwgkynxlwrj")));
+ .withValue("opvfg")
+ .withSensitiveValue("rxumwdqwy")));
model = BinaryData.fromObject(model).toObject(SsisEnvironment.class);
- Assertions.assertEquals(1315044173320403578L, model.id());
- Assertions.assertEquals("mcktkal", model.name());
- Assertions.assertEquals("i", model.description());
- Assertions.assertEquals(8944070795440540678L, model.folderId());
- Assertions.assertEquals(8456784201907262272L, model.variables().get(0).id());
- Assertions.assertEquals("nwnlcfzfjdzkfth", model.variables().get(0).name());
- Assertions.assertEquals("dphdb", model.variables().get(0).description());
- Assertions.assertEquals("etfgkzqbvh", model.variables().get(0).dataType());
- Assertions.assertEquals(false, model.variables().get(0).sensitive());
- Assertions.assertEquals("ymkgjsry", model.variables().get(0).value());
- Assertions.assertEquals("f", model.variables().get(0).sensitiveValue());
+ Assertions.assertEquals(5882503334253851296L, model.id());
+ Assertions.assertEquals("eleqpnk", model.name());
+ Assertions.assertEquals("krum", model.description());
+ Assertions.assertEquals(6305964571481835052L, model.folderId());
+ Assertions.assertEquals(8018758763891691267L, model.variables().get(0).id());
+ Assertions.assertEquals("mny", model.variables().get(0).name());
+ Assertions.assertEquals("tgslkokq", model.variables().get(0).description());
+ Assertions.assertEquals("gzcojgdq", model.variables().get(0).dataType());
+ Assertions.assertEquals(true, model.variables().get(0).sensitive());
+ Assertions.assertEquals("ecjgpjnydkkgbv", model.variables().get(0).value());
+ Assertions.assertEquals("ks", model.variables().get(0).sensitiveValue());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisExecutionParameterTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisExecutionParameterTests.java
index acb2a25f2caa..2df0a13fdebe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisExecutionParameterTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisExecutionParameterTests.java
@@ -11,12 +11,12 @@ public final class SsisExecutionParameterTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisExecutionParameter model
- = BinaryData.fromString("{\"value\":\"datarbfepfwr\"}").toObject(SsisExecutionParameter.class);
+ = BinaryData.fromString("{\"value\":\"dataiblaumogu\"}").toObject(SsisExecutionParameter.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisExecutionParameter model = new SsisExecutionParameter().withValue("datarbfepfwr");
+ SsisExecutionParameter model = new SsisExecutionParameter().withValue("dataiblaumogu");
model = BinaryData.fromObject(model).toObject(SsisExecutionParameter.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisFolderTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisFolderTests.java
index 46b63c015c2a..a20ba6eb501e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisFolderTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisFolderTests.java
@@ -12,20 +12,20 @@ public final class SsisFolderTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisFolder model = BinaryData.fromString(
- "{\"type\":\"Folder\",\"id\":5928487509100506530,\"name\":\"iqcypmonfcorcn\",\"description\":\"ycigcb\"}")
+ "{\"type\":\"Folder\",\"id\":276539782360188700,\"name\":\"qsvru\",\"description\":\"yncppmmwhjerlurg\"}")
.toObject(SsisFolder.class);
- Assertions.assertEquals(5928487509100506530L, model.id());
- Assertions.assertEquals("iqcypmonfcorcn", model.name());
- Assertions.assertEquals("ycigcb", model.description());
+ Assertions.assertEquals(276539782360188700L, model.id());
+ Assertions.assertEquals("qsvru", model.name());
+ Assertions.assertEquals("yncppmmwhjerlurg", model.description());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SsisFolder model
- = new SsisFolder().withId(5928487509100506530L).withName("iqcypmonfcorcn").withDescription("ycigcb");
+ = new SsisFolder().withId(276539782360188700L).withName("qsvru").withDescription("yncppmmwhjerlurg");
model = BinaryData.fromObject(model).toObject(SsisFolder.class);
- Assertions.assertEquals(5928487509100506530L, model.id());
- Assertions.assertEquals("iqcypmonfcorcn", model.name());
- Assertions.assertEquals("ycigcb", model.description());
+ Assertions.assertEquals(276539782360188700L, model.id());
+ Assertions.assertEquals("qsvru", model.name());
+ Assertions.assertEquals("yncppmmwhjerlurg", model.description());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPackageTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPackageTests.java
index 31f7f3f0a246..a412103fa35c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPackageTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPackageTests.java
@@ -14,66 +14,66 @@ public final class SsisPackageTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisPackage model = BinaryData.fromString(
- "{\"type\":\"Package\",\"folderId\":1265248644139343981,\"projectVersion\":8942635865838153344,\"projectId\":8374572896451975526,\"parameters\":[{\"id\":1354465321346670595,\"name\":\"whfjoxseh\",\"description\":\"cgqcrwaucftotedh\",\"dataType\":\"dlmuhff\",\"required\":false,\"sensitive\":true,\"designDefaultValue\":\"qmpmsk\",\"defaultValue\":\"xrhljwqufud\",\"sensitiveDefaultValue\":\"pboqle\",\"valueType\":\"fpwmajvwfi\",\"valueSet\":true,\"variable\":\"j\"}],\"id\":476712109086344208,\"name\":\"msmrihddnbwlbq\",\"description\":\"dderrxyiwuzpsvcm\"}")
+ "{\"type\":\"Package\",\"folderId\":6056512355996014897,\"projectVersion\":4550609594207854420,\"projectId\":8576241744456427452,\"parameters\":[{\"id\":4305402148108255233,\"name\":\"vllpfjguzsy\",\"description\":\"am\",\"dataType\":\"eoxxbzagwnompvy\",\"required\":false,\"sensitive\":true,\"designDefaultValue\":\"ufysalbjfkjex\",\"defaultValue\":\"zmh\",\"sensitiveDefaultValue\":\"idipwczjnnmpifj\",\"valueType\":\"jen\",\"valueSet\":false,\"variable\":\"fpllosadjffllrs\"}],\"id\":6883034740159153282,\"name\":\"eoka\",\"description\":\"uddcc\"}")
.toObject(SsisPackage.class);
- Assertions.assertEquals(476712109086344208L, model.id());
- Assertions.assertEquals("msmrihddnbwlbq", model.name());
- Assertions.assertEquals("dderrxyiwuzpsvcm", model.description());
- Assertions.assertEquals(1265248644139343981L, model.folderId());
- Assertions.assertEquals(8942635865838153344L, model.projectVersion());
- Assertions.assertEquals(8374572896451975526L, model.projectId());
- Assertions.assertEquals(1354465321346670595L, model.parameters().get(0).id());
- Assertions.assertEquals("whfjoxseh", model.parameters().get(0).name());
- Assertions.assertEquals("cgqcrwaucftotedh", model.parameters().get(0).description());
- Assertions.assertEquals("dlmuhff", model.parameters().get(0).dataType());
+ Assertions.assertEquals(6883034740159153282L, model.id());
+ Assertions.assertEquals("eoka", model.name());
+ Assertions.assertEquals("uddcc", model.description());
+ Assertions.assertEquals(6056512355996014897L, model.folderId());
+ Assertions.assertEquals(4550609594207854420L, model.projectVersion());
+ Assertions.assertEquals(8576241744456427452L, model.projectId());
+ Assertions.assertEquals(4305402148108255233L, model.parameters().get(0).id());
+ Assertions.assertEquals("vllpfjguzsy", model.parameters().get(0).name());
+ Assertions.assertEquals("am", model.parameters().get(0).description());
+ Assertions.assertEquals("eoxxbzagwnompvy", model.parameters().get(0).dataType());
Assertions.assertEquals(false, model.parameters().get(0).required());
Assertions.assertEquals(true, model.parameters().get(0).sensitive());
- Assertions.assertEquals("qmpmsk", model.parameters().get(0).designDefaultValue());
- Assertions.assertEquals("xrhljwqufud", model.parameters().get(0).defaultValue());
- Assertions.assertEquals("pboqle", model.parameters().get(0).sensitiveDefaultValue());
- Assertions.assertEquals("fpwmajvwfi", model.parameters().get(0).valueType());
- Assertions.assertEquals(true, model.parameters().get(0).valueSet());
- Assertions.assertEquals("j", model.parameters().get(0).variable());
+ Assertions.assertEquals("ufysalbjfkjex", model.parameters().get(0).designDefaultValue());
+ Assertions.assertEquals("zmh", model.parameters().get(0).defaultValue());
+ Assertions.assertEquals("idipwczjnnmpifj", model.parameters().get(0).sensitiveDefaultValue());
+ Assertions.assertEquals("jen", model.parameters().get(0).valueType());
+ Assertions.assertEquals(false, model.parameters().get(0).valueSet());
+ Assertions.assertEquals("fpllosadjffllrs", model.parameters().get(0).variable());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisPackage model = new SsisPackage().withId(476712109086344208L)
- .withName("msmrihddnbwlbq")
- .withDescription("dderrxyiwuzpsvcm")
- .withFolderId(1265248644139343981L)
- .withProjectVersion(8942635865838153344L)
- .withProjectId(8374572896451975526L)
- .withParameters(Arrays.asList(new SsisParameter().withId(1354465321346670595L)
- .withName("whfjoxseh")
- .withDescription("cgqcrwaucftotedh")
- .withDataType("dlmuhff")
+ SsisPackage model = new SsisPackage().withId(6883034740159153282L)
+ .withName("eoka")
+ .withDescription("uddcc")
+ .withFolderId(6056512355996014897L)
+ .withProjectVersion(4550609594207854420L)
+ .withProjectId(8576241744456427452L)
+ .withParameters(Arrays.asList(new SsisParameter().withId(4305402148108255233L)
+ .withName("vllpfjguzsy")
+ .withDescription("am")
+ .withDataType("eoxxbzagwnompvy")
.withRequired(false)
.withSensitive(true)
- .withDesignDefaultValue("qmpmsk")
- .withDefaultValue("xrhljwqufud")
- .withSensitiveDefaultValue("pboqle")
- .withValueType("fpwmajvwfi")
- .withValueSet(true)
- .withVariable("j")));
+ .withDesignDefaultValue("ufysalbjfkjex")
+ .withDefaultValue("zmh")
+ .withSensitiveDefaultValue("idipwczjnnmpifj")
+ .withValueType("jen")
+ .withValueSet(false)
+ .withVariable("fpllosadjffllrs")));
model = BinaryData.fromObject(model).toObject(SsisPackage.class);
- Assertions.assertEquals(476712109086344208L, model.id());
- Assertions.assertEquals("msmrihddnbwlbq", model.name());
- Assertions.assertEquals("dderrxyiwuzpsvcm", model.description());
- Assertions.assertEquals(1265248644139343981L, model.folderId());
- Assertions.assertEquals(8942635865838153344L, model.projectVersion());
- Assertions.assertEquals(8374572896451975526L, model.projectId());
- Assertions.assertEquals(1354465321346670595L, model.parameters().get(0).id());
- Assertions.assertEquals("whfjoxseh", model.parameters().get(0).name());
- Assertions.assertEquals("cgqcrwaucftotedh", model.parameters().get(0).description());
- Assertions.assertEquals("dlmuhff", model.parameters().get(0).dataType());
+ Assertions.assertEquals(6883034740159153282L, model.id());
+ Assertions.assertEquals("eoka", model.name());
+ Assertions.assertEquals("uddcc", model.description());
+ Assertions.assertEquals(6056512355996014897L, model.folderId());
+ Assertions.assertEquals(4550609594207854420L, model.projectVersion());
+ Assertions.assertEquals(8576241744456427452L, model.projectId());
+ Assertions.assertEquals(4305402148108255233L, model.parameters().get(0).id());
+ Assertions.assertEquals("vllpfjguzsy", model.parameters().get(0).name());
+ Assertions.assertEquals("am", model.parameters().get(0).description());
+ Assertions.assertEquals("eoxxbzagwnompvy", model.parameters().get(0).dataType());
Assertions.assertEquals(false, model.parameters().get(0).required());
Assertions.assertEquals(true, model.parameters().get(0).sensitive());
- Assertions.assertEquals("qmpmsk", model.parameters().get(0).designDefaultValue());
- Assertions.assertEquals("xrhljwqufud", model.parameters().get(0).defaultValue());
- Assertions.assertEquals("pboqle", model.parameters().get(0).sensitiveDefaultValue());
- Assertions.assertEquals("fpwmajvwfi", model.parameters().get(0).valueType());
- Assertions.assertEquals(true, model.parameters().get(0).valueSet());
- Assertions.assertEquals("j", model.parameters().get(0).variable());
+ Assertions.assertEquals("ufysalbjfkjex", model.parameters().get(0).designDefaultValue());
+ Assertions.assertEquals("zmh", model.parameters().get(0).defaultValue());
+ Assertions.assertEquals("idipwczjnnmpifj", model.parameters().get(0).sensitiveDefaultValue());
+ Assertions.assertEquals("jen", model.parameters().get(0).valueType());
+ Assertions.assertEquals(false, model.parameters().get(0).valueSet());
+ Assertions.assertEquals("fpllosadjffllrs", model.parameters().get(0).variable());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisParameterTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisParameterTests.java
index 86a6f5582da0..0d983b9b2e0d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisParameterTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisParameterTests.java
@@ -12,48 +12,48 @@ public final class SsisParameterTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisParameter model = BinaryData.fromString(
- "{\"id\":8967425448877390786,\"name\":\"rwqtb\",\"description\":\"sdta\",\"dataType\":\"y\",\"required\":true,\"sensitive\":false,\"designDefaultValue\":\"omywlypghh\",\"defaultValue\":\"u\",\"sensitiveDefaultValue\":\"fvg\",\"valueType\":\"wgiqmb\",\"valueSet\":true,\"variable\":\"mbuihtqfvyq\"}")
+ "{\"id\":2973458827491706517,\"name\":\"xugpubeq\",\"description\":\"xzmuzgueuygpbha\",\"dataType\":\"e\",\"required\":false,\"sensitive\":false,\"designDefaultValue\":\"ygx\",\"defaultValue\":\"xw\",\"sensitiveDefaultValue\":\"qwdjvlwq\",\"valueType\":\"yylw\",\"valueSet\":false,\"variable\":\"cmejezj\"}")
.toObject(SsisParameter.class);
- Assertions.assertEquals(8967425448877390786L, model.id());
- Assertions.assertEquals("rwqtb", model.name());
- Assertions.assertEquals("sdta", model.description());
- Assertions.assertEquals("y", model.dataType());
- Assertions.assertEquals(true, model.required());
+ Assertions.assertEquals(2973458827491706517L, model.id());
+ Assertions.assertEquals("xugpubeq", model.name());
+ Assertions.assertEquals("xzmuzgueuygpbha", model.description());
+ Assertions.assertEquals("e", model.dataType());
+ Assertions.assertEquals(false, model.required());
Assertions.assertEquals(false, model.sensitive());
- Assertions.assertEquals("omywlypghh", model.designDefaultValue());
- Assertions.assertEquals("u", model.defaultValue());
- Assertions.assertEquals("fvg", model.sensitiveDefaultValue());
- Assertions.assertEquals("wgiqmb", model.valueType());
- Assertions.assertEquals(true, model.valueSet());
- Assertions.assertEquals("mbuihtqfvyq", model.variable());
+ Assertions.assertEquals("ygx", model.designDefaultValue());
+ Assertions.assertEquals("xw", model.defaultValue());
+ Assertions.assertEquals("qwdjvlwq", model.sensitiveDefaultValue());
+ Assertions.assertEquals("yylw", model.valueType());
+ Assertions.assertEquals(false, model.valueSet());
+ Assertions.assertEquals("cmejezj", model.variable());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisParameter model = new SsisParameter().withId(8967425448877390786L)
- .withName("rwqtb")
- .withDescription("sdta")
- .withDataType("y")
- .withRequired(true)
+ SsisParameter model = new SsisParameter().withId(2973458827491706517L)
+ .withName("xugpubeq")
+ .withDescription("xzmuzgueuygpbha")
+ .withDataType("e")
+ .withRequired(false)
.withSensitive(false)
- .withDesignDefaultValue("omywlypghh")
- .withDefaultValue("u")
- .withSensitiveDefaultValue("fvg")
- .withValueType("wgiqmb")
- .withValueSet(true)
- .withVariable("mbuihtqfvyq");
+ .withDesignDefaultValue("ygx")
+ .withDefaultValue("xw")
+ .withSensitiveDefaultValue("qwdjvlwq")
+ .withValueType("yylw")
+ .withValueSet(false)
+ .withVariable("cmejezj");
model = BinaryData.fromObject(model).toObject(SsisParameter.class);
- Assertions.assertEquals(8967425448877390786L, model.id());
- Assertions.assertEquals("rwqtb", model.name());
- Assertions.assertEquals("sdta", model.description());
- Assertions.assertEquals("y", model.dataType());
- Assertions.assertEquals(true, model.required());
+ Assertions.assertEquals(2973458827491706517L, model.id());
+ Assertions.assertEquals("xugpubeq", model.name());
+ Assertions.assertEquals("xzmuzgueuygpbha", model.description());
+ Assertions.assertEquals("e", model.dataType());
+ Assertions.assertEquals(false, model.required());
Assertions.assertEquals(false, model.sensitive());
- Assertions.assertEquals("omywlypghh", model.designDefaultValue());
- Assertions.assertEquals("u", model.defaultValue());
- Assertions.assertEquals("fvg", model.sensitiveDefaultValue());
- Assertions.assertEquals("wgiqmb", model.valueType());
- Assertions.assertEquals(true, model.valueSet());
- Assertions.assertEquals("mbuihtqfvyq", model.variable());
+ Assertions.assertEquals("ygx", model.designDefaultValue());
+ Assertions.assertEquals("xw", model.defaultValue());
+ Assertions.assertEquals("qwdjvlwq", model.sensitiveDefaultValue());
+ Assertions.assertEquals("yylw", model.valueType());
+ Assertions.assertEquals(false, model.valueSet());
+ Assertions.assertEquals("cmejezj", model.variable());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisProjectTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisProjectTests.java
index c4e7ed84cec8..1a2912747954 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisProjectTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisProjectTests.java
@@ -15,88 +15,121 @@ public final class SsisProjectTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisProject model = BinaryData.fromString(
- "{\"type\":\"Project\",\"folderId\":1402483351488265161,\"version\":2381115839441940754,\"environmentRefs\":[{\"id\":1379544178862142488,\"environmentFolderName\":\"jzdjqzbr\",\"environmentName\":\"frmhoufokrbg\",\"referenceType\":\"jcksirs\"}],\"parameters\":[{\"id\":2068039513298288479,\"name\":\"lyxdeggnzadqmvp\",\"description\":\"pnsvkyq\",\"dataType\":\"pl\",\"required\":false,\"sensitive\":true,\"designDefaultValue\":\"jsrgclxnsvbkhh\",\"defaultValue\":\"sytue\",\"sensitiveDefaultValue\":\"gukywdp\",\"valueType\":\"wlcexkrpitqz\",\"valueSet\":false,\"variable\":\"eujcmtci\"},{\"id\":6519184799798061845,\"name\":\"nxhcxct\",\"description\":\"xoef\",\"dataType\":\"orylx\",\"required\":false,\"sensitive\":false,\"designDefaultValue\":\"zvq\",\"defaultValue\":\"ymtupyjtrxxzwdsn\",\"sensitiveDefaultValue\":\"yefnakdmtpjksdlu\",\"valueType\":\"tjxhxwt\",\"valueSet\":false,\"variable\":\"nvukvupu\"}],\"id\":1051284638662928792,\"name\":\"lynvpdvctqdapyds\",\"description\":\"zpjbsilbn\"}")
+ "{\"type\":\"Project\",\"folderId\":2534337512728361991,\"version\":9204988078857470987,\"environmentRefs\":[{\"id\":3325608952724918572,\"environmentFolderName\":\"gpxd\",\"environmentName\":\"cqmguvdk\",\"referenceType\":\"ihrfcowla\"},{\"id\":4156102790350782968,\"environmentFolderName\":\"ywxjjylaqhxevfd\",\"environmentName\":\"vjhwgkynxlwrjgo\",\"referenceType\":\"tmcktkalhpiy\"},{\"id\":3297149062864782819,\"environmentFolderName\":\"lzrignqlwogqnb\",\"environmentName\":\"aiuvemqc\",\"referenceType\":\"kivexiathmar\"}],\"parameters\":[{\"id\":7853401833151195182,\"name\":\"nkbfxq\",\"description\":\"pggeciradmx\",\"dataType\":\"butbbzcxzayvcsej\",\"required\":false,\"sensitive\":false,\"designDefaultValue\":\"iitr\",\"defaultValue\":\"djtgo\",\"sensitiveDefaultValue\":\"ybseckgaxm\",\"valueType\":\"szjietfs\",\"valueSet\":false,\"variable\":\"dvzcnlk\"},{\"id\":765164696607468515,\"name\":\"kreisojhuswm\",\"description\":\"bkob\",\"dataType\":\"wav\",\"required\":false,\"sensitive\":false,\"designDefaultValue\":\"lwidtebwedjri\",\"defaultValue\":\"ppgijn\",\"sensitiveDefaultValue\":\"ba\",\"valueType\":\"xepgaxpy\",\"valueSet\":false,\"variable\":\"cqdssbmgersdudh\"},{\"id\":7742128413945850057,\"name\":\"fg\",\"description\":\"xtxfuh\",\"dataType\":\"ksfyz\",\"required\":true,\"sensitive\":true,\"designDefaultValue\":\"lffnozzfysffrpjf\",\"defaultValue\":\"yx\",\"sensitiveDefaultValue\":\"osyhhwpuf\",\"valueType\":\"preyilq\",\"valueSet\":true,\"variable\":\"kteoykqr\"},{\"id\":3917509054195107271,\"name\":\"grddi\",\"description\":\"a\",\"dataType\":\"lyrbvmbdgexp\",\"required\":true,\"sensitive\":false,\"designDefaultValue\":\"fpjpsbcxqiyapi\",\"defaultValue\":\"jlfugnrzowcgrz\",\"sensitiveDefaultValue\":\"q\",\"valueType\":\"zawqxnhlva\",\"valueSet\":false,\"variable\":\"xdwtfmf\"}],\"id\":2696284877511045447,\"name\":\"lhaljomgzorpr\",\"description\":\"ptvbjenylg\"}")
.toObject(SsisProject.class);
- Assertions.assertEquals(1051284638662928792L, model.id());
- Assertions.assertEquals("lynvpdvctqdapyds", model.name());
- Assertions.assertEquals("zpjbsilbn", model.description());
- Assertions.assertEquals(1402483351488265161L, model.folderId());
- Assertions.assertEquals(2381115839441940754L, model.version());
- Assertions.assertEquals(1379544178862142488L, model.environmentRefs().get(0).id());
- Assertions.assertEquals("jzdjqzbr", model.environmentRefs().get(0).environmentFolderName());
- Assertions.assertEquals("frmhoufokrbg", model.environmentRefs().get(0).environmentName());
- Assertions.assertEquals("jcksirs", model.environmentRefs().get(0).referenceType());
- Assertions.assertEquals(2068039513298288479L, model.parameters().get(0).id());
- Assertions.assertEquals("lyxdeggnzadqmvp", model.parameters().get(0).name());
- Assertions.assertEquals("pnsvkyq", model.parameters().get(0).description());
- Assertions.assertEquals("pl", model.parameters().get(0).dataType());
+ Assertions.assertEquals(2696284877511045447L, model.id());
+ Assertions.assertEquals("lhaljomgzorpr", model.name());
+ Assertions.assertEquals("ptvbjenylg", model.description());
+ Assertions.assertEquals(2534337512728361991L, model.folderId());
+ Assertions.assertEquals(9204988078857470987L, model.version());
+ Assertions.assertEquals(3325608952724918572L, model.environmentRefs().get(0).id());
+ Assertions.assertEquals("gpxd", model.environmentRefs().get(0).environmentFolderName());
+ Assertions.assertEquals("cqmguvdk", model.environmentRefs().get(0).environmentName());
+ Assertions.assertEquals("ihrfcowla", model.environmentRefs().get(0).referenceType());
+ Assertions.assertEquals(7853401833151195182L, model.parameters().get(0).id());
+ Assertions.assertEquals("nkbfxq", model.parameters().get(0).name());
+ Assertions.assertEquals("pggeciradmx", model.parameters().get(0).description());
+ Assertions.assertEquals("butbbzcxzayvcsej", model.parameters().get(0).dataType());
Assertions.assertEquals(false, model.parameters().get(0).required());
- Assertions.assertEquals(true, model.parameters().get(0).sensitive());
- Assertions.assertEquals("jsrgclxnsvbkhh", model.parameters().get(0).designDefaultValue());
- Assertions.assertEquals("sytue", model.parameters().get(0).defaultValue());
- Assertions.assertEquals("gukywdp", model.parameters().get(0).sensitiveDefaultValue());
- Assertions.assertEquals("wlcexkrpitqz", model.parameters().get(0).valueType());
+ Assertions.assertEquals(false, model.parameters().get(0).sensitive());
+ Assertions.assertEquals("iitr", model.parameters().get(0).designDefaultValue());
+ Assertions.assertEquals("djtgo", model.parameters().get(0).defaultValue());
+ Assertions.assertEquals("ybseckgaxm", model.parameters().get(0).sensitiveDefaultValue());
+ Assertions.assertEquals("szjietfs", model.parameters().get(0).valueType());
Assertions.assertEquals(false, model.parameters().get(0).valueSet());
- Assertions.assertEquals("eujcmtci", model.parameters().get(0).variable());
+ Assertions.assertEquals("dvzcnlk", model.parameters().get(0).variable());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisProject model = new SsisProject().withId(1051284638662928792L)
- .withName("lynvpdvctqdapyds")
- .withDescription("zpjbsilbn")
- .withFolderId(1402483351488265161L)
- .withVersion(2381115839441940754L)
- .withEnvironmentRefs(Arrays.asList(new SsisEnvironmentReference().withId(1379544178862142488L)
- .withEnvironmentFolderName("jzdjqzbr")
- .withEnvironmentName("frmhoufokrbg")
- .withReferenceType("jcksirs")))
+ SsisProject model = new SsisProject().withId(2696284877511045447L)
+ .withName("lhaljomgzorpr")
+ .withDescription("ptvbjenylg")
+ .withFolderId(2534337512728361991L)
+ .withVersion(9204988078857470987L)
+ .withEnvironmentRefs(Arrays.asList(
+ new SsisEnvironmentReference().withId(3325608952724918572L)
+ .withEnvironmentFolderName("gpxd")
+ .withEnvironmentName("cqmguvdk")
+ .withReferenceType("ihrfcowla"),
+ new SsisEnvironmentReference().withId(4156102790350782968L)
+ .withEnvironmentFolderName("ywxjjylaqhxevfd")
+ .withEnvironmentName("vjhwgkynxlwrjgo")
+ .withReferenceType("tmcktkalhpiy"),
+ new SsisEnvironmentReference().withId(3297149062864782819L)
+ .withEnvironmentFolderName("lzrignqlwogqnb")
+ .withEnvironmentName("aiuvemqc")
+ .withReferenceType("kivexiathmar")))
.withParameters(Arrays.asList(
- new SsisParameter().withId(2068039513298288479L)
- .withName("lyxdeggnzadqmvp")
- .withDescription("pnsvkyq")
- .withDataType("pl")
+ new SsisParameter().withId(7853401833151195182L)
+ .withName("nkbfxq")
+ .withDescription("pggeciradmx")
+ .withDataType("butbbzcxzayvcsej")
.withRequired(false)
- .withSensitive(true)
- .withDesignDefaultValue("jsrgclxnsvbkhh")
- .withDefaultValue("sytue")
- .withSensitiveDefaultValue("gukywdp")
- .withValueType("wlcexkrpitqz")
+ .withSensitive(false)
+ .withDesignDefaultValue("iitr")
+ .withDefaultValue("djtgo")
+ .withSensitiveDefaultValue("ybseckgaxm")
+ .withValueType("szjietfs")
.withValueSet(false)
- .withVariable("eujcmtci"),
- new SsisParameter().withId(6519184799798061845L)
- .withName("nxhcxct")
- .withDescription("xoef")
- .withDataType("orylx")
+ .withVariable("dvzcnlk"),
+ new SsisParameter().withId(765164696607468515L)
+ .withName("kreisojhuswm")
+ .withDescription("bkob")
+ .withDataType("wav")
.withRequired(false)
.withSensitive(false)
- .withDesignDefaultValue("zvq")
- .withDefaultValue("ymtupyjtrxxzwdsn")
- .withSensitiveDefaultValue("yefnakdmtpjksdlu")
- .withValueType("tjxhxwt")
+ .withDesignDefaultValue("lwidtebwedjri")
+ .withDefaultValue("ppgijn")
+ .withSensitiveDefaultValue("ba")
+ .withValueType("xepgaxpy")
+ .withValueSet(false)
+ .withVariable("cqdssbmgersdudh"),
+ new SsisParameter().withId(7742128413945850057L)
+ .withName("fg")
+ .withDescription("xtxfuh")
+ .withDataType("ksfyz")
+ .withRequired(true)
+ .withSensitive(true)
+ .withDesignDefaultValue("lffnozzfysffrpjf")
+ .withDefaultValue("yx")
+ .withSensitiveDefaultValue("osyhhwpuf")
+ .withValueType("preyilq")
+ .withValueSet(true)
+ .withVariable("kteoykqr"),
+ new SsisParameter().withId(3917509054195107271L)
+ .withName("grddi")
+ .withDescription("a")
+ .withDataType("lyrbvmbdgexp")
+ .withRequired(true)
+ .withSensitive(false)
+ .withDesignDefaultValue("fpjpsbcxqiyapi")
+ .withDefaultValue("jlfugnrzowcgrz")
+ .withSensitiveDefaultValue("q")
+ .withValueType("zawqxnhlva")
.withValueSet(false)
- .withVariable("nvukvupu")));
+ .withVariable("xdwtfmf")));
model = BinaryData.fromObject(model).toObject(SsisProject.class);
- Assertions.assertEquals(1051284638662928792L, model.id());
- Assertions.assertEquals("lynvpdvctqdapyds", model.name());
- Assertions.assertEquals("zpjbsilbn", model.description());
- Assertions.assertEquals(1402483351488265161L, model.folderId());
- Assertions.assertEquals(2381115839441940754L, model.version());
- Assertions.assertEquals(1379544178862142488L, model.environmentRefs().get(0).id());
- Assertions.assertEquals("jzdjqzbr", model.environmentRefs().get(0).environmentFolderName());
- Assertions.assertEquals("frmhoufokrbg", model.environmentRefs().get(0).environmentName());
- Assertions.assertEquals("jcksirs", model.environmentRefs().get(0).referenceType());
- Assertions.assertEquals(2068039513298288479L, model.parameters().get(0).id());
- Assertions.assertEquals("lyxdeggnzadqmvp", model.parameters().get(0).name());
- Assertions.assertEquals("pnsvkyq", model.parameters().get(0).description());
- Assertions.assertEquals("pl", model.parameters().get(0).dataType());
+ Assertions.assertEquals(2696284877511045447L, model.id());
+ Assertions.assertEquals("lhaljomgzorpr", model.name());
+ Assertions.assertEquals("ptvbjenylg", model.description());
+ Assertions.assertEquals(2534337512728361991L, model.folderId());
+ Assertions.assertEquals(9204988078857470987L, model.version());
+ Assertions.assertEquals(3325608952724918572L, model.environmentRefs().get(0).id());
+ Assertions.assertEquals("gpxd", model.environmentRefs().get(0).environmentFolderName());
+ Assertions.assertEquals("cqmguvdk", model.environmentRefs().get(0).environmentName());
+ Assertions.assertEquals("ihrfcowla", model.environmentRefs().get(0).referenceType());
+ Assertions.assertEquals(7853401833151195182L, model.parameters().get(0).id());
+ Assertions.assertEquals("nkbfxq", model.parameters().get(0).name());
+ Assertions.assertEquals("pggeciradmx", model.parameters().get(0).description());
+ Assertions.assertEquals("butbbzcxzayvcsej", model.parameters().get(0).dataType());
Assertions.assertEquals(false, model.parameters().get(0).required());
- Assertions.assertEquals(true, model.parameters().get(0).sensitive());
- Assertions.assertEquals("jsrgclxnsvbkhh", model.parameters().get(0).designDefaultValue());
- Assertions.assertEquals("sytue", model.parameters().get(0).defaultValue());
- Assertions.assertEquals("gukywdp", model.parameters().get(0).sensitiveDefaultValue());
- Assertions.assertEquals("wlcexkrpitqz", model.parameters().get(0).valueType());
+ Assertions.assertEquals(false, model.parameters().get(0).sensitive());
+ Assertions.assertEquals("iitr", model.parameters().get(0).designDefaultValue());
+ Assertions.assertEquals("djtgo", model.parameters().get(0).defaultValue());
+ Assertions.assertEquals("ybseckgaxm", model.parameters().get(0).sensitiveDefaultValue());
+ Assertions.assertEquals("szjietfs", model.parameters().get(0).valueType());
Assertions.assertEquals(false, model.parameters().get(0).valueSet());
- Assertions.assertEquals("eujcmtci", model.parameters().get(0).variable());
+ Assertions.assertEquals("dvzcnlk", model.parameters().get(0).variable());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPropertyOverrideTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPropertyOverrideTests.java
index d61779be4b58..d4bd79d33014 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPropertyOverrideTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisPropertyOverrideTests.java
@@ -11,15 +11,15 @@
public final class SsisPropertyOverrideTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SsisPropertyOverride model = BinaryData.fromString("{\"value\":\"datantaaftdysev\",\"isSensitive\":true}")
+ SsisPropertyOverride model = BinaryData.fromString("{\"value\":\"dataxwmwrjm\",\"isSensitive\":false}")
.toObject(SsisPropertyOverride.class);
- Assertions.assertEquals(true, model.isSensitive());
+ Assertions.assertEquals(false, model.isSensitive());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisPropertyOverride model = new SsisPropertyOverride().withValue("datantaaftdysev").withIsSensitive(true);
+ SsisPropertyOverride model = new SsisPropertyOverride().withValue("dataxwmwrjm").withIsSensitive(false);
model = BinaryData.fromObject(model).toObject(SsisPropertyOverride.class);
- Assertions.assertEquals(true, model.isSensitive());
+ Assertions.assertEquals(false, model.isSensitive());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisVariableTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisVariableTests.java
index ad349ef7b9fc..45ccb9685091 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisVariableTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SsisVariableTests.java
@@ -12,33 +12,33 @@ public final class SsisVariableTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SsisVariable model = BinaryData.fromString(
- "{\"id\":1492874499782202267,\"name\":\"y\",\"description\":\"rignqlwogqn\",\"dataType\":\"uaiuvemqcb\",\"sensitive\":true,\"value\":\"exiathmaryywyf\",\"sensitiveValue\":\"nkbfxq\"}")
+ "{\"id\":8399935683656414000,\"name\":\"o\",\"description\":\"wjx\",\"dataType\":\"wxiyarfh\",\"sensitive\":false,\"value\":\"tidzvvndpr\",\"sensitiveValue\":\"uexhgdhpkplas\"}")
.toObject(SsisVariable.class);
- Assertions.assertEquals(1492874499782202267L, model.id());
- Assertions.assertEquals("y", model.name());
- Assertions.assertEquals("rignqlwogqn", model.description());
- Assertions.assertEquals("uaiuvemqcb", model.dataType());
- Assertions.assertEquals(true, model.sensitive());
- Assertions.assertEquals("exiathmaryywyf", model.value());
- Assertions.assertEquals("nkbfxq", model.sensitiveValue());
+ Assertions.assertEquals(8399935683656414000L, model.id());
+ Assertions.assertEquals("o", model.name());
+ Assertions.assertEquals("wjx", model.description());
+ Assertions.assertEquals("wxiyarfh", model.dataType());
+ Assertions.assertEquals(false, model.sensitive());
+ Assertions.assertEquals("tidzvvndpr", model.value());
+ Assertions.assertEquals("uexhgdhpkplas", model.sensitiveValue());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SsisVariable model = new SsisVariable().withId(1492874499782202267L)
- .withName("y")
- .withDescription("rignqlwogqn")
- .withDataType("uaiuvemqcb")
- .withSensitive(true)
- .withValue("exiathmaryywyf")
- .withSensitiveValue("nkbfxq");
+ SsisVariable model = new SsisVariable().withId(8399935683656414000L)
+ .withName("o")
+ .withDescription("wjx")
+ .withDataType("wxiyarfh")
+ .withSensitive(false)
+ .withValue("tidzvvndpr")
+ .withSensitiveValue("uexhgdhpkplas");
model = BinaryData.fromObject(model).toObject(SsisVariable.class);
- Assertions.assertEquals(1492874499782202267L, model.id());
- Assertions.assertEquals("y", model.name());
- Assertions.assertEquals("rignqlwogqn", model.description());
- Assertions.assertEquals("uaiuvemqcb", model.dataType());
- Assertions.assertEquals(true, model.sensitive());
- Assertions.assertEquals("exiathmaryywyf", model.value());
- Assertions.assertEquals("nkbfxq", model.sensitiveValue());
+ Assertions.assertEquals(8399935683656414000L, model.id());
+ Assertions.assertEquals("o", model.name());
+ Assertions.assertEquals("wjx", model.description());
+ Assertions.assertEquals("wxiyarfh", model.dataType());
+ Assertions.assertEquals(false, model.sensitive());
+ Assertions.assertEquals("tidzvvndpr", model.value());
+ Assertions.assertEquals("uexhgdhpkplas", model.sensitiveValue());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StagingSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StagingSettingsTests.java
index e3ef56807c53..8cbf4bf23928 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StagingSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StagingSettingsTests.java
@@ -15,21 +15,22 @@ public final class StagingSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
StagingSettings model = BinaryData.fromString(
- "{\"linkedServiceName\":{\"referenceName\":\"qspzwsxnyoc\",\"parameters\":{\"btkcvola\":\"datassusdrgzmmrzwm\"}},\"path\":\"dataukgov\",\"enableCompression\":\"datamndcqo\",\"\":{\"zgvaeqiygbo\":\"dataiyhmjwsnwk\",\"odidgudarclajben\":\"datavz\",\"kff\":\"datayuufvoj\"}}")
+ "{\"linkedServiceName\":{\"referenceName\":\"qjftyaqdswfn\",\"parameters\":{\"u\":\"dataiwhumngihfndsj\",\"offckejx\":\"datalfvrpbcgdptf\",\"qwxxynttrn\":\"datamng\"}},\"path\":\"datavximgns\",\"enableCompression\":\"datacxuyzrnngnmf\",\"\":{\"tpyqalwlirapqhsi\":\"datafoummdomvd\",\"efgfqxejj\":\"datafhsfnoc\",\"fcrb\":\"datatiqbxzeiudog\",\"wzbew\":\"dataoeomufaza\"}}")
.toObject(StagingSettings.class);
- Assertions.assertEquals("qspzwsxnyoc", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("qjftyaqdswfn", model.linkedServiceName().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
StagingSettings model = new StagingSettings()
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qspzwsxnyoc")
- .withParameters(mapOf("btkcvola", "datassusdrgzmmrzwm")))
- .withPath("dataukgov")
- .withEnableCompression("datamndcqo")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("qjftyaqdswfn")
+ .withParameters(
+ mapOf("u", "dataiwhumngihfndsj", "offckejx", "datalfvrpbcgdptf", "qwxxynttrn", "datamng")))
+ .withPath("datavximgns")
+ .withEnableCompression("datacxuyzrnngnmf")
.withAdditionalProperties(mapOf());
model = BinaryData.fromObject(model).toObject(StagingSettings.class);
- Assertions.assertEquals("qspzwsxnyoc", model.linkedServiceName().referenceName());
+ Assertions.assertEquals("qjftyaqdswfn", model.linkedServiceName().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreReadSettingsTests.java
index 10649810a0ff..18a61537e2c1 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreReadSettingsTests.java
@@ -13,14 +13,14 @@ public final class StoreReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
StoreReadSettings model = BinaryData.fromString(
- "{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"dataouxpdnlbp\",\"disableMetricsCollection\":\"datackohn\",\"\":{\"gurwxfspxghw\":\"dataqzek\",\"w\":\"dataiyuofegrzfsfuloo\",\"qsylkkqvmmm\":\"datazotjbvhuidlod\"}}")
+ "{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datarvjwbeeol\",\"disableMetricsCollection\":\"databaqolwfkb\",\"\":{\"vazf\":\"datavhtgfdygaphlwm\"}}")
.toObject(StoreReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- StoreReadSettings model = new StoreReadSettings().withMaxConcurrentConnections("dataouxpdnlbp")
- .withDisableMetricsCollection("datackohn")
+ StoreReadSettings model = new StoreReadSettings().withMaxConcurrentConnections("datarvjwbeeol")
+ .withDisableMetricsCollection("databaqolwfkb")
.withAdditionalProperties(mapOf("type", "StoreReadSettings"));
model = BinaryData.fromObject(model).toObject(StoreReadSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreWriteSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreWriteSettingsTests.java
index 52562eff1d12..618785c81633 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreWriteSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/StoreWriteSettingsTests.java
@@ -15,17 +15,19 @@ public final class StoreWriteSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
StoreWriteSettings model = BinaryData.fromString(
- "{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"datafdxauihnb\",\"disableMetricsCollection\":\"datahkdwyehqnxuffgj\",\"copyBehavior\":\"dataminhvdkqigppdqsq\",\"metadata\":[{\"name\":\"dataeaxthuhuruouqy\",\"value\":\"dataapstkdbnqjpcu\"}],\"\":{\"mfkumbysgsqzpgr\":\"datao\",\"phlfrxrpahptv\":\"datafag\",\"qllolnxhsupilhx\":\"datakfenmiflky\",\"y\":\"dataabli\"}}")
+ "{\"type\":\"StoreWriteSettings\",\"maxConcurrentConnections\":\"dataekbpqghxdpg\",\"disableMetricsCollection\":\"datafimlyx\",\"copyBehavior\":\"dataixjudbiac\",\"metadata\":[{\"name\":\"datacmfuvuslvbujwpnz\",\"value\":\"datapyyvecruhq\"},{\"name\":\"datawdsthktsaljk\",\"value\":\"datapgtpgxkkoyp\"},{\"name\":\"datalvthivapuax\",\"value\":\"datawqwbhlrzlg\"},{\"name\":\"datanpdkwerx\",\"value\":\"datazlmzsekvsuzyowra\"}],\"\":{\"nuvpkplt\":\"datafr\",\"atfpbxnretpg\":\"datayyey\"}}")
.toObject(StoreWriteSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- StoreWriteSettings model = new StoreWriteSettings().withMaxConcurrentConnections("datafdxauihnb")
- .withDisableMetricsCollection("datahkdwyehqnxuffgj")
- .withCopyBehavior("dataminhvdkqigppdqsq")
- .withMetadata(
- Arrays.asList(new MetadataItem().withName("dataeaxthuhuruouqy").withValue("dataapstkdbnqjpcu")))
+ StoreWriteSettings model = new StoreWriteSettings().withMaxConcurrentConnections("dataekbpqghxdpg")
+ .withDisableMetricsCollection("datafimlyx")
+ .withCopyBehavior("dataixjudbiac")
+ .withMetadata(Arrays.asList(new MetadataItem().withName("datacmfuvuslvbujwpnz").withValue("datapyyvecruhq"),
+ new MetadataItem().withName("datawdsthktsaljk").withValue("datapgtpgxkkoyp"),
+ new MetadataItem().withName("datalvthivapuax").withValue("datawqwbhlrzlg"),
+ new MetadataItem().withName("datanpdkwerx").withValue("datazlmzsekvsuzyowra")))
.withAdditionalProperties(mapOf("type", "StoreWriteSettings"));
model = BinaryData.fromObject(model).toObject(StoreWriteSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTests.java
index d4e5ee297122..019af154799f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTests.java
@@ -23,299 +23,232 @@ public final class SwitchActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SwitchActivity model = BinaryData.fromString(
- "{\"type\":\"Switch\",\"typeProperties\":{\"on\":{\"value\":\"a\"},\"cases\":[{\"value\":\"fenpz\",\"activities\":[{\"type\":\"Activity\",\"name\":\"tn\",\"description\":\"ghcmxigexqy\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"yceuywuio\",\"dependencyConditions\":[]},{\"activity\":\"mtwhyznlhaki\",\"dependencyConditions\":[]},{\"activity\":\"skg\",\"dependencyConditions\":[]},{\"activity\":\"fmdp\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"qorpkulzqjqbwjiq\",\"value\":\"dataukbjuakd\"},{\"name\":\"mwajalsen\",\"value\":\"datadoslvfdvbslrhcce\"},{\"name\":\"objsjunzwbb\",\"value\":\"datavx\"}],\"\":{\"dvx\":\"dataukuh\",\"inrq\":\"datadmitmjccnjvgftmp\"}},{\"type\":\"Activity\",\"name\":\"liqxahpy\",\"description\":\"cngduewevhcwt\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"xigpmc\",\"dependencyConditions\":[]},{\"activity\":\"equocawcb\",\"dependencyConditions\":[]},{\"activity\":\"nyljycpwh\",\"dependencyConditions\":[]},{\"activity\":\"btxzaaav\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"dygoadtdx\",\"value\":\"dataxrkrvmhhgv\"},{\"name\":\"xvsuwbvrbwafwi\",\"value\":\"dataktncigwfgvpft\"},{\"name\":\"wmuxcpyqbv\",\"value\":\"datapmghh\"},{\"name\":\"mxptkbehpywvgf\",\"value\":\"datasrngyqvxzqwcm\"}],\"\":{\"nnyksskuscdnn\":\"datapfcvvk\",\"tjtqww\":\"dataoftapyrh\",\"c\":\"dataaxhsjw\"}},{\"type\":\"Activity\",\"name\":\"twywhrzntmzzzavx\",\"description\":\"kexspoiq\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"aisywop\",\"dependencyConditions\":[]},{\"activity\":\"ovlwmaig\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"byldsmyqm\",\"value\":\"datavqth\"},{\"name\":\"imvyzrdqpgyonkr\",\"value\":\"dataxwldktphn\"},{\"name\":\"sijcjnbtgfitpx\",\"value\":\"datakb\"}],\"\":{\"bd\":\"datajxbbyq\"}}]},{\"value\":\"zkujgeppxiyovg\",\"activities\":[{\"type\":\"Activity\",\"name\":\"m\",\"description\":\"oggameacjoa\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"kgvwvlqqnf\",\"dependencyConditions\":[]},{\"activity\":\"wrws\",\"dependencyConditions\":[]},{\"activity\":\"yblwjhpibgalefjs\",\"dependencyConditions\":[]},{\"activity\":\"nxrgmvzcibqy\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"shnbfdwxsjptsk\",\"value\":\"datargztzcibowqmfh\"},{\"name\":\"hnbsxoebephohjo\",\"value\":\"datag\"}],\"\":{\"ngkqejrhwyyzz\":\"datachvrgb\"}},{\"type\":\"Activity\",\"name\":\"lfayichwcf\",\"description\":\"ywpwjvpglst\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"j\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"n\",\"value\":\"dataddygpdn\"},{\"name\":\"vepbocwbcx\",\"value\":\"datadbxdkopummphbf\"},{\"name\":\"riv\",\"value\":\"datailxpp\"},{\"name\":\"zyen\",\"value\":\"datajj\"}],\"\":{\"qolj\":\"datadpnersmevhgs\"}},{\"type\":\"Activity\",\"name\":\"vrjqakbhzsyqp\",\"description\":\"vbxgrgyguq\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"gzeio\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"ngiaadgx\",\"value\":\"datazhyceteidf\"},{\"name\":\"ofmcnnicmlomlnpr\",\"value\":\"dataikyn\"}],\"\":{\"ogabcwvibjfkc\":\"datagquphqnuitumxhve\"}},{\"type\":\"Activity\",\"name\":\"zanr\",\"description\":\"jdmdb\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"uohijjlaxe\",\"dependencyConditions\":[]},{\"activity\":\"ehgrjgvrawjom\",\"dependencyConditions\":[]},{\"activity\":\"gb\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"fyagv\",\"value\":\"dataegptcuqzdwpcu\"},{\"name\":\"ejzozndapxxgvc\",\"value\":\"datavtflcjxmteexap\"}],\"\":{\"rutcedeygsrrgd\":\"datadfi\"}}]}],\"defaultActivities\":[{\"type\":\"Activity\",\"name\":\"qy\",\"description\":\"ah\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"wo\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Skipped\"],\"\":{\"kag\":\"datayrkcdo\",\"jlq\":\"dataaitihncysa\"}}],\"userProperties\":[{\"name\":\"aqtbiskkcebj\",\"value\":\"datajlptydve\"}],\"\":{\"k\":\"datakeonixxiukghxd\"}},{\"type\":\"Activity\",\"name\":\"ptvxi\",\"description\":\"zhknjuevzqawj\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"bpfeisjgh\",\"dependencyConditions\":[\"Completed\",\"Skipped\"],\"\":{\"wu\":\"datadrlbbpkjseft\",\"naqyeswinoecwabu\":\"datafmakn\",\"eqayvkmp\":\"dataqflwskb\"}},{\"activity\":\"gpqxiyllamdz\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"sxpcbglbpa\":\"datakdbo\",\"ggf\":\"databc\",\"xtbdgp\":\"datao\"}}],\"userProperties\":[{\"name\":\"lbdcglimacztky\",\"value\":\"datayvztdho\"},{\"name\":\"arcumpxd\",\"value\":\"datayohbbtwpkgc\"},{\"name\":\"uem\",\"value\":\"datacjejaly\"}],\"\":{\"uvdoteidcwrmdq\":\"dataumt\"}},{\"type\":\"Activity\",\"name\":\"gtwegqmlviymcyfs\",\"description\":\"uzmzgat\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"saerzc\",\"dependencyConditions\":[\"Skipped\",\"Completed\"],\"\":{\"xgqxdd\":\"datawzgiozz\",\"zscxikjyjcsh\":\"datauiuriwbvyra\"}},{\"activity\":\"tp\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"vckfivia\":\"datakmybohax\",\"raohiyeyfsvuy\":\"dataqnnmcdqzgepjyppk\",\"cuzpjnakqcs\":\"datay\"}},{\"activity\":\"oozyxugieitpokjy\",\"dependencyConditions\":[\"Skipped\",\"Skipped\"],\"\":{\"bkljj\":\"dataznifpxiqpjnqyylk\",\"lxdhoagcu\":\"datauirmcupbehqbmhqi\",\"haw\":\"dataocvctmpxnbnhogb\"}},{\"activity\":\"efgett\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Skipped\"],\"\":{\"qkbvhd\":\"datapmbx\",\"tcucfbr\":\"datagnbcwfpgvmixfqqm\"}}],\"userProperties\":[{\"name\":\"dtz\",\"value\":\"datagw\"},{\"name\":\"rvpcwyn\",\"value\":\"dataqikouravdqe\"},{\"name\":\"ewgpmademlo\",\"value\":\"datama\"},{\"name\":\"kbmkkun\",\"value\":\"datahgdvgcgunqitzwn\"}],\"\":{\"qjrdydzqeuppxdz\":\"dataevtof\",\"g\":\"datajewpslyszwkrko\",\"tfgbxiao\":\"datanxly\"}},{\"type\":\"Activity\",\"name\":\"zrouwkkwtoxl\",\"description\":\"pvealwdltstxro\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"eakzysakrx\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"jwkdwpcm\":\"datafqc\"}},{\"activity\":\"q\",\"dependencyConditions\":[\"Completed\",\"Failed\"],\"\":{\"wxoreedoruiyc\":\"datalay\",\"itrsppucxigkpevt\":\"dataourqdmz\",\"dggwaldtelnvcfum\":\"datalmrjla\"}},{\"activity\":\"z\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Skipped\"],\"\":{\"mapxnoogmfujecis\":\"dataklzgiq\",\"umpydk\":\"datacmezexwzpgywnljy\",\"sczcksjwdwzfdfkg\":\"databcufhkrvxxzhqouo\"}}],\"userProperties\":[{\"name\":\"wvmbsmxh\",\"value\":\"dataqdotbnfbn\"},{\"name\":\"ybotuqzjfkuqvter\",\"value\":\"datasgw\"},{\"name\":\"ykcvwqyfixw\",\"value\":\"dataq\"},{\"name\":\"xmiw\",\"value\":\"dataz\"}],\"\":{\"uxutkwb\":\"datalypuxbnv\",\"nqwkaevbgjhmy\":\"datattmvaijnz\"}}]},\"name\":\"sqovmtidmyc\",\"description\":\"ajlnotmir\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"b\",\"dependencyConditions\":[\"Failed\"],\"\":{\"dmfrfzg\":\"datay\"}},{\"activity\":\"njaqzdzkyqq\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Failed\"],\"\":{\"tdeyoxtlq\":\"datatwmmvbahftkcey\",\"tepzrcqnsjqrgtap\":\"datatx\"}},{\"activity\":\"wpzphkm\",\"dependencyConditions\":[\"Completed\"],\"\":{\"ndb\":\"datakl\",\"zsxp\":\"datalqtpebaa\"}},{\"activity\":\"rbjtjvqdwz\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\"],\"\":{\"unfuk\":\"dataenieqlikyc\",\"adhpr\":\"datahxvktlrca\"}}],\"userProperties\":[{\"name\":\"wnrqfi\",\"value\":\"dataqamxxpfyl\"},{\"name\":\"pftw\",\"value\":\"datae\"}],\"\":{\"aolfdgjrgp\":\"datartgww\",\"kzznarnjueq\":\"datapvohvcaqarp\",\"zoihtncadrmthh\":\"datauzjgv\",\"ndfrxn\":\"dataxyznnpazbfrqotig\"}}")
+ "{\"type\":\"Switch\",\"typeProperties\":{\"on\":{\"value\":\"fskgxfmdpsreqor\"},\"cases\":[{\"value\":\"zqjqbwjiqru\",\"activities\":[{\"type\":\"Activity\",\"name\":\"uakd\",\"description\":\"wajal\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"lvfdvbslrhccey\",\"dependencyConditions\":[]},{\"activity\":\"bjsjunzwbby\",\"dependencyConditions\":[]},{\"activity\":\"xkvfuku\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"vxidmitmjccnjvg\",\"value\":\"datatmpjinrqgliq\"}],\"\":{\"wttqiresixigp\":\"datapysscngduewevh\",\"ycpwhybtxzaaa\":\"datacmequocawcbknyl\",\"xrkrvmhhgv\":\"dataeiadygoadtdx\",\"ktncigwfgvpft\":\"dataxvsuwbvrbwafwi\"}},{\"type\":\"Activity\",\"name\":\"wmuxcpyqbv\",\"description\":\"mghhzm\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"pywvgfdsrng\",\"dependencyConditions\":[]},{\"activity\":\"qvxzqwcmmolpfcv\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"nnyksskuscdnn\",\"value\":\"dataoftapyrh\"},{\"name\":\"tjtqww\",\"value\":\"dataaxhsjw\"},{\"name\":\"c\",\"value\":\"datatwywhrzntmzzzavx\"}],\"\":{\"teaisywopko\":\"dataexspoiqvuky\",\"cbyldsmyq\":\"datalwmaigd\"}},{\"type\":\"Activity\",\"name\":\"gvqthlimvyzrdqpg\",\"description\":\"nk\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"tphnisijcj\",\"dependencyConditions\":[]},{\"activity\":\"btgfitpxpkb\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"jxbbyq\",\"value\":\"databd\"}],\"\":{\"m\":\"datakujgeppxiyovgha\",\"ameacjoaixhma\":\"datacog\",\"yblwjhpibgalefjs\":\"datakkgvwvlqqnfdwrws\",\"qnshnbfd\":\"datanxrgmvzcibqy\"}},{\"type\":\"Activity\",\"name\":\"xs\",\"description\":\"tskprgztzcib\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"hnbsxoebephohjo\",\"dependencyConditions\":[]},{\"activity\":\"g\",\"dependencyConditions\":[]},{\"activity\":\"ifchvr\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"ngkqejrhwyyzz\",\"value\":\"datalfayichwcf\"},{\"name\":\"bywpwjvpgls\",\"value\":\"dataxznkbjkjez\"},{\"name\":\"n\",\"value\":\"dataddygpdn\"}],\"\":{\"bxd\":\"datapbocwbcxw\",\"ive\":\"dataopummphbfp\",\"ppizyenajjxz\":\"datal\"}}]},{\"value\":\"pnersmevhgsuq\",\"activities\":[{\"type\":\"Activity\",\"name\":\"lvrjqa\",\"description\":\"hzsyqpkpvbxgr\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"v\",\"dependencyConditions\":[]},{\"activity\":\"yivgzeiocacngi\",\"dependencyConditions\":[]},{\"activity\":\"adgx\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"yceteidf\",\"value\":\"dataofmcnnicmlomlnpr\"},{\"name\":\"ikyn\",\"value\":\"datacsgquphqnuitu\"},{\"name\":\"xhv\",\"value\":\"datamogabcwvib\"},{\"name\":\"fkcmzanrut\",\"value\":\"datad\"}],\"\":{\"qehgrjgvrawjom\":\"datatbdtrqiuohijjlax\",\"dwfyagvhe\":\"datagb\"}},{\"type\":\"Activity\",\"name\":\"ptcuqzdwpcupejzo\",\"description\":\"dapxxgvcsvtflcj\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"pf\",\"dependencyConditions\":[]},{\"activity\":\"pdfi\",\"dependencyConditions\":[]},{\"activity\":\"rutcedeygsrrgd\",\"dependencyConditions\":[]},{\"activity\":\"maqyesahvowlibr\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"dwzzacyrkc\",\"value\":\"dataokkagkaitihncysa\"},{\"name\":\"jlq\",\"value\":\"dataora\"}],\"\":{\"kkcebjaj\":\"datai\"}},{\"type\":\"Activity\",\"name\":\"ptydve\",\"description\":\"pkeo\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"ghx\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"qptvxibpzhkn\",\"value\":\"datauevzqawjnwj\"}],\"\":{\"sjghfaldxsd\":\"dataubpfe\",\"jseftvwu\":\"datalbbp\",\"naqyeswinoecwabu\":\"datafmakn\",\"eqayvkmp\":\"dataqflwskb\"}}]}],\"defaultActivities\":[{\"type\":\"Activity\",\"name\":\"qxiyllamdz\",\"description\":\"j\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"esxpcbglbpahbc\",\"dependencyConditions\":[\"Failed\"],\"\":{\"xtbdgp\":\"datao\",\"macztkypyvztd\":\"datadclbdcgl\",\"xdyyo\":\"dataoyarcum\"}},{\"activity\":\"bbtwpkg\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Completed\"],\"\":{\"doteidc\":\"datajejalybvxumtxu\",\"viymcyfszlu\":\"datarmdqqgtwegqm\"}},{\"activity\":\"mzgattagroejsae\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Failed\",\"Skipped\"],\"\":{\"rxgq\":\"datazwzgioz\",\"uriwbvyra\":\"dataddvu\",\"tp\":\"datazscxikjyjcsh\",\"b\":\"datavuixmkm\"}}],\"userProperties\":[{\"name\":\"xmvckf\",\"value\":\"dataviadqnnmcdqzgep\"}],\"\":{\"fraohiyeyfsvuy\":\"datap\",\"cuzpjnakqcs\":\"datay\",\"hkrklzn\":\"dataoozyxugieitpokjy\",\"yylkcbkljjiuirmc\":\"datafpxiqpjn\"}}]},\"name\":\"pbehqbmhqihlxdho\",\"description\":\"cuoocv\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"nho\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\"],\"\":{\"bxnqkbvhdbg\":\"datarefgetttzlokttp\",\"vmixfqqm\":\"databcwfp\",\"m\":\"datatcucfbr\",\"gw\":\"datadtz\"}},{\"activity\":\"rvpcwyn\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Completed\"],\"\":{\"gpmad\":\"dataavdqeue\",\"nfhgdvgcgun\":\"datamloimaykbmkk\"}},{\"activity\":\"itzwndpkev\",\"dependencyConditions\":[\"Failed\"],\"\":{\"euppxdzpjewp\":\"datajrdydz\",\"rkokgrnxly\":\"datalyszw\",\"zrouwkkwtoxl\":\"datatfgbxiao\",\"vealwdltstxronbz\":\"datan\"}},{\"activity\":\"keeeakzys\",\"dependencyConditions\":[\"Skipped\",\"Failed\"],\"\":{\"kdwpcmy\":\"datatajdfqchj\",\"eedoruiycvourqd\":\"datadrrkfhlaygwxo\"}}],\"userProperties\":[{\"name\":\"itrsppucxigkpevt\",\"value\":\"datalmrjla\"},{\"name\":\"dggwaldtelnvcfum\",\"value\":\"dataz\"},{\"name\":\"zhiradklzg\",\"value\":\"dataqmmapxnoog\"}],\"\":{\"icmezexwzpgy\":\"datajeci\",\"umpydk\":\"datanljy\",\"sczcksjwdwzfdfkg\":\"databcufhkrvxxzhqouo\",\"vmbsmxhsqdotbnf\":\"datala\"}}")
.toObject(SwitchActivity.class);
- Assertions.assertEquals("sqovmtidmyc", model.name());
- Assertions.assertEquals("ajlnotmir", model.description());
+ Assertions.assertEquals("pbehqbmhqihlxdho", model.name());
+ Assertions.assertEquals("cuoocv", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("b", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("wnrqfi", model.userProperties().get(0).name());
- Assertions.assertEquals("a", model.on().value());
- Assertions.assertEquals("fenpz", model.cases().get(0).value());
- Assertions.assertEquals("tn", model.cases().get(0).activities().get(0).name());
- Assertions.assertEquals("ghcmxigexqy", model.cases().get(0).activities().get(0).description());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("nho", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("itrsppucxigkpevt", model.userProperties().get(0).name());
+ Assertions.assertEquals("fskgxfmdpsreqor", model.on().value());
+ Assertions.assertEquals("zqjqbwjiqru", model.cases().get(0).value());
+ Assertions.assertEquals("uakd", model.cases().get(0).activities().get(0).name());
+ Assertions.assertEquals("wajal", model.cases().get(0).activities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.cases().get(0).activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED,
model.cases().get(0).activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("yceuywuio", model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals("qorpkulzqjqbwjiq",
+ Assertions.assertEquals("lvfdvbslrhccey",
+ model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("vxidmitmjccnjvg",
model.cases().get(0).activities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("qy", model.defaultActivities().get(0).name());
- Assertions.assertEquals("ah", model.defaultActivities().get(0).description());
+ Assertions.assertEquals("qxiyllamdz", model.defaultActivities().get(0).name());
+ Assertions.assertEquals("j", model.defaultActivities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, model.defaultActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.defaultActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("wo", model.defaultActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.defaultActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("esxpcbglbpahbc", model.defaultActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED,
model.defaultActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("aqtbiskkcebj", model.defaultActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("xmvckf", model.defaultActivities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SwitchActivity model = new SwitchActivity().withName("sqovmtidmyc")
- .withDescription("ajlnotmir")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("b")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("njaqzdzkyqq")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED,
- DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wpzphkm")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("rbjtjvqdwz")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("wnrqfi").withValue("dataqamxxpfyl"),
- new UserProperty().withName("pftw").withValue("datae")))
- .withOn(new Expression().withValue("a"))
- .withCases(Arrays.asList(
- new SwitchCase().withValue("fenpz")
- .withActivities(Arrays.asList(
- new Activity().withName("tn")
- .withDescription("ghcmxigexqy")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("yceuywuio")
+ SwitchActivity model
+ = new SwitchActivity().withName("pbehqbmhqihlxdho")
+ .withDescription("cuoocv")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("nho")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("rvpcwyn")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("itzwndpkev")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("keeeakzys")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("itrsppucxigkpevt").withValue("datalmrjla"),
+ new UserProperty().withName("dggwaldtelnvcfum").withValue("dataz"),
+ new UserProperty().withName("zhiradklzg").withValue("dataqmmapxnoog")))
+ .withOn(new Expression().withValue("fskgxfmdpsreqor"))
+ .withCases(Arrays.asList(
+ new SwitchCase().withValue("zqjqbwjiqru")
+ .withActivities(Arrays.asList(
+ new Activity().withName("uakd")
+ .withDescription("wajal")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("lvfdvbslrhccey")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("bjsjunzwbby")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("xkvfuku")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("vxidmitmjccnjvg").withValue("datatmpjinrqgliq")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("wmuxcpyqbv")
+ .withDescription("mghhzm")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("pywvgfdsrng")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("qvxzqwcmmolpfcv")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("nnyksskuscdnn").withValue("dataoftapyrh"),
+ new UserProperty().withName("tjtqww").withValue("dataaxhsjw"),
+ new UserProperty().withName("c").withValue("datatwywhrzntmzzzavx")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("gvqthlimvyzrdqpg")
+ .withDescription("nk")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("tphnisijcj")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("btgfitpxpkb")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("jxbbyq").withValue("databd")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("xs")
+ .withDescription("tskprgztzcib")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("hnbsxoebephohjo")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("g")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ifchvr")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("ngkqejrhwyyzz").withValue("datalfayichwcf"),
+ new UserProperty().withName("bywpwjvpgls").withValue("dataxznkbjkjez"),
+ new UserProperty().withName("n").withValue("dataddygpdn")))
+ .withAdditionalProperties(mapOf("type", "Activity")))),
+ new SwitchCase().withValue("pnersmevhgsuq")
+ .withActivities(Arrays.asList(
+ new Activity().withName("lvrjqa")
+ .withDescription("hzsyqpkpvbxgr")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("v")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("yivgzeiocacngi")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("adgx")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays
+ .asList(new UserProperty().withName("yceteidf").withValue("dataofmcnnicmlomlnpr"),
+ new UserProperty().withName("ikyn").withValue("datacsgquphqnuitu"),
+ new UserProperty().withName("xhv").withValue("datamogabcwvib"),
+ new UserProperty().withName("fkcmzanrut").withValue("datad")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("ptcuqzdwpcupejzo")
+ .withDescription("dapxxgvcsvtflcj")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("pf")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("pdfi")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("rutcedeygsrrgd")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("maqyesahvowlibr")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("dwzzacyrkc").withValue("dataokkagkaitihncysa"),
+ new UserProperty().withName("jlq").withValue("dataora")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("ptydve")
+ .withDescription("pkeo")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("ghx")
.withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("mtwhyznlhaki")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("skg")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("fmdp")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("qorpkulzqjqbwjiq").withValue("dataukbjuakd"),
- new UserProperty().withName("mwajalsen").withValue("datadoslvfdvbslrhcce"),
- new UserProperty().withName("objsjunzwbb").withValue("datavx")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("liqxahpy")
- .withDescription("cngduewevhcwt")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("xigpmc")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("equocawcb")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("nyljycpwh")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("btxzaaav")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("dygoadtdx").withValue("dataxrkrvmhhgv"),
- new UserProperty().withName("xvsuwbvrbwafwi").withValue("dataktncigwfgvpft"),
- new UserProperty().withName("wmuxcpyqbv").withValue("datapmghh"),
- new UserProperty().withName("mxptkbehpywvgf").withValue("datasrngyqvxzqwcm")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("twywhrzntmzzzavx")
- .withDescription("kexspoiq")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("aisywop")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ovlwmaig")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("byldsmyqm").withValue("datavqth"),
- new UserProperty().withName("imvyzrdqpgyonkr").withValue("dataxwldktphn"),
- new UserProperty().withName("sijcjnbtgfitpx").withValue("datakb")))
- .withAdditionalProperties(mapOf("type", "Activity")))),
- new SwitchCase().withValue("zkujgeppxiyovg")
- .withActivities(Arrays.asList(
- new Activity().withName("m")
- .withDescription("oggameacjoa")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("kgvwvlqqnf")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wrws")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("yblwjhpibgalefjs")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("nxrgmvzcibqy")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(
- new UserProperty().withName("shnbfdwxsjptsk").withValue("datargztzcibowqmfh"),
- new UserProperty().withName("hnbsxoebephohjo").withValue("datag")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("lfayichwcf")
- .withDescription("ywpwjvpglst")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("j")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("n").withValue("dataddygpdn"),
- new UserProperty().withName("vepbocwbcx").withValue("datadbxdkopummphbf"),
- new UserProperty().withName("riv").withValue("datailxpp"),
- new UserProperty().withName("zyen").withValue("datajj")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("vrjqakbhzsyqp")
- .withDescription("vbxgrgyguq")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("gzeio")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("ngiaadgx").withValue("datazhyceteidf"),
- new UserProperty().withName("ofmcnnicmlomlnpr").withValue("dataikyn")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("zanr")
- .withDescription("jdmdb")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("uohijjlaxe")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ehgrjgvrawjom")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("gb")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("fyagv").withValue("dataegptcuqzdwpcu"),
- new UserProperty().withName("ejzozndapxxgvc").withValue("datavtflcjxmteexap")))
- .withAdditionalProperties(mapOf("type", "Activity"))))))
- .withDefaultActivities(
- Arrays
- .asList(
- new Activity().withName("qy")
- .withDescription("ah")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("wo")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("aqtbiskkcebj")
- .withValue("datajlptydve")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("ptvxi")
- .withDescription("zhknjuevzqawj")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(
- Arrays
- .asList(
- new ActivityDependency().withActivity("bpfeisjgh")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("gpqxiyllamdz")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays
- .asList(new UserProperty().withName("lbdcglimacztky")
- .withValue("datayvztdho"),
- new UserProperty().withName("arcumpxd").withValue("datayohbbtwpkgc"),
- new UserProperty().withName("uem").withValue("datacjejaly")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("gtwegqmlviymcyfs")
- .withDescription("uzmzgat")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(
- Arrays
- .asList(
- new ActivityDependency().withActivity("saerzc")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("tp")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("oozyxugieitpokjy")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("efgett")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("dtz").withValue("datagw"),
- new UserProperty().withName("rvpcwyn").withValue("dataqikouravdqe"),
- new UserProperty().withName("ewgpmademlo").withValue("datama"),
- new UserProperty().withName("kbmkkun").withValue("datahgdvgcgunqitzwn")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("zrouwkkwtoxl")
- .withDescription("pvealwdltstxro")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("eakzysakrx")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("q")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("z")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("wvmbsmxh").withValue("dataqdotbnfbn"),
- new UserProperty().withName("ybotuqzjfkuqvter").withValue("datasgw"),
- new UserProperty().withName("ykcvwqyfixw").withValue("dataq"),
- new UserProperty().withName("xmiw").withValue("dataz")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ .withUserProperties(Arrays
+ .asList(new UserProperty().withName("qptvxibpzhkn").withValue("datauevzqawjnwj")))
+ .withAdditionalProperties(mapOf("type", "Activity"))))))
+ .withDefaultActivities(Arrays.asList(new Activity().withName("qxiyllamdz")
+ .withDescription("j")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("esxpcbglbpahbc")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("bbtwpkg")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("mzgattagroejsae")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.SKIPPED, DependencyCondition.FAILED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("xmvckf").withValue("dataviadqnnmcdqzgep")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(SwitchActivity.class);
- Assertions.assertEquals("sqovmtidmyc", model.name());
- Assertions.assertEquals("ajlnotmir", model.description());
+ Assertions.assertEquals("pbehqbmhqihlxdho", model.name());
+ Assertions.assertEquals("cuoocv", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("b", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("wnrqfi", model.userProperties().get(0).name());
- Assertions.assertEquals("a", model.on().value());
- Assertions.assertEquals("fenpz", model.cases().get(0).value());
- Assertions.assertEquals("tn", model.cases().get(0).activities().get(0).name());
- Assertions.assertEquals("ghcmxigexqy", model.cases().get(0).activities().get(0).description());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("nho", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SKIPPED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("itrsppucxigkpevt", model.userProperties().get(0).name());
+ Assertions.assertEquals("fskgxfmdpsreqor", model.on().value());
+ Assertions.assertEquals("zqjqbwjiqru", model.cases().get(0).value());
+ Assertions.assertEquals("uakd", model.cases().get(0).activities().get(0).name());
+ Assertions.assertEquals("wajal", model.cases().get(0).activities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.cases().get(0).activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED,
model.cases().get(0).activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("yceuywuio", model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals("qorpkulzqjqbwjiq",
+ Assertions.assertEquals("lvfdvbslrhccey",
+ model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("vxidmitmjccnjvg",
model.cases().get(0).activities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("qy", model.defaultActivities().get(0).name());
- Assertions.assertEquals("ah", model.defaultActivities().get(0).description());
+ Assertions.assertEquals("qxiyllamdz", model.defaultActivities().get(0).name());
+ Assertions.assertEquals("j", model.defaultActivities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, model.defaultActivities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.defaultActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("wo", model.defaultActivities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.defaultActivities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("esxpcbglbpahbc", model.defaultActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.FAILED,
model.defaultActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("aqtbiskkcebj", model.defaultActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("xmvckf", model.defaultActivities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTypePropertiesTests.java
index 04f92ceefb73..484f596246ef 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchActivityTypePropertiesTests.java
@@ -23,106 +23,258 @@ public final class SwitchActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SwitchActivityTypeProperties model = BinaryData.fromString(
- "{\"on\":{\"value\":\"wqyhklhossc\"},\"cases\":[{\"value\":\"ungjb\",\"activities\":[{\"type\":\"Activity\",\"name\":\"sjgmes\",\"description\":\"hxkjjhflrg\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"dgqpbgzyaf\",\"dependencyConditions\":[]},{\"activity\":\"zwieizzxjjdb\",\"dependencyConditions\":[]},{\"activity\":\"xuinrsrrijcwn\",\"dependencyConditions\":[]},{\"activity\":\"htqtbcwtcqjsvlzd\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"zbvdzjlkocjuajcl\",\"value\":\"datatssbkzdgwpyljn\"},{\"name\":\"iprjahgqzb\",\"value\":\"dataicyufnum\"}],\"\":{\"hmuryajppuflvazp\":\"datahnru\",\"sqmli\":\"datazo\",\"lpobzvxntsf\":\"databvfa\"}}]}],\"defaultActivities\":[{\"type\":\"Activity\",\"name\":\"kfzi\",\"description\":\"bwthvww\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"fgpj\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Failed\",\"Skipped\"],\"\":{\"hwxdwlowy\":\"dataufpdwknxe\",\"uoxkvpl\":\"dataeqiqnjcajm\",\"jfldzvgogqu\":\"dataooomnq\",\"naxfvsyustrb\":\"datagaofobjl\"}}],\"userProperties\":[{\"name\":\"bjbknpzhfhi\",\"value\":\"datahgwbslrqbd\"},{\"name\":\"cjbxochijwpsk\",\"value\":\"dataeprumhikwahbz\"},{\"name\":\"gwkimmvatrv\",\"value\":\"datakxcrxqpenkujxdn\"}],\"\":{\"qytppjdyikdykxh\":\"dataeterjerhwgiuduw\"}},{\"type\":\"Activity\",\"name\":\"rkdtucyutrp\",\"description\":\"mukmmcvfti\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"jynefxaed\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"fzavsajb\":\"dataw\",\"xysmqee\":\"datahshyxhfejtywl\",\"jwqmcaofxgw\":\"datadfplwfsmpbwwp\",\"tedzxujxkxjrttzh\":\"datavjefnlxq\"}},{\"activity\":\"ambjqynwqcov\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Skipped\",\"Skipped\"],\"\":{\"rcmayqasdve\":\"datahhbddxkoj\"}}],\"userProperties\":[{\"name\":\"a\",\"value\":\"dataxmpyvlfujsbcfogu\"},{\"name\":\"bqcqnchdzyju\",\"value\":\"datadknblbrixvcp\"},{\"name\":\"svprumttrvkhu\",\"value\":\"dataxtx\"},{\"name\":\"w\",\"value\":\"datajbanlmpmvegxgymx\"}],\"\":{\"gqhqu\":\"datatu\",\"ybgpjyuvjuowk\":\"datanj\",\"dqcgedipnnzmvt\":\"dataebpvhdk\",\"ee\":\"datattjmdtfuwx\"}}]}")
+ "{\"on\":{\"value\":\"niybotuq\"},\"cases\":[{\"value\":\"uqvterbsgwoyk\",\"activities\":[{\"type\":\"Activity\",\"name\":\"qyfixwgqmxm\",\"description\":\"fzr\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"bnvqu\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"kwbsttmvaijn\",\"value\":\"dataqnqwkaevbg\"},{\"name\":\"hmyzsqovmtid\",\"value\":\"dataycyyajl\"},{\"name\":\"otmir\",\"value\":\"dataipnclnbfxme\"}],\"\":{\"njaqzdzkyqq\":\"datadmfrfzg\",\"ahf\":\"dataqbwbwvtwmmv\"}},{\"type\":\"Activity\",\"name\":\"kceyjtdeyoxtlqyt\",\"description\":\"tepzrcqnsjqrgtap\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"mwbtr\",\"dependencyConditions\":[]},{\"activity\":\"kl\",\"dependencyConditions\":[]},{\"activity\":\"ndb\",\"dependencyConditions\":[]},{\"activity\":\"lqtpebaa\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"xpy\",\"value\":\"databjtjvqdwzyvxdg\"},{\"name\":\"enieqlikyc\",\"value\":\"dataunfuk\"}],\"\":{\"prjs\":\"datavktlrcauad\",\"qamxxpfyl\":\"datawnrqfi\",\"e\":\"datapftw\"}},{\"type\":\"Activity\",\"name\":\"uortgwwtaolfdgjr\",\"description\":\"hpvohvcaq\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"na\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"ueqouzjgvqz\",\"value\":\"dataihtn\"},{\"name\":\"adrmt\",\"value\":\"datahfxy\"},{\"name\":\"nn\",\"value\":\"dataazbfrqo\"},{\"name\":\"igxndfrxnvwqy\",\"value\":\"datakl\"}],\"\":{\"iungjbfmrsjgme\":\"datascpj\",\"xkjjhflrg\":\"dataam\",\"adgqpbgzyafazwie\":\"dataskgh\",\"rijcwnthtq\":\"datazzxjjdboxuinrs\"}},{\"type\":\"Activity\",\"name\":\"bcwtcqjsvlzdus\",\"description\":\"b\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"cjuajclrtssbk\",\"dependencyConditions\":[]},{\"activity\":\"dgwpyljn\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"rjah\",\"value\":\"dataq\"},{\"name\":\"byic\",\"value\":\"dataufnumf\"}],\"\":{\"flvazp\":\"datanruqhmuryajpp\"}}]},{\"value\":\"ossqm\",\"activities\":[{\"type\":\"Activity\",\"name\":\"bvfa\",\"description\":\"pobzvxntsfyntkfz\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"vwwhmldsn\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"pjkk\",\"value\":\"dataaenzuuf\"},{\"name\":\"d\",\"value\":\"dataknxep\"},{\"name\":\"wxdwlo\",\"value\":\"dataymeqiqnjcajmxu\"},{\"name\":\"xkvpleooom\",\"value\":\"dataqdjfldzvgo\"}],\"\":{\"ustr\":\"datacgaofobjlqnaxfvs\"}},{\"type\":\"Activity\",\"name\":\"je\",\"description\":\"jbknpzhfhibhgwb\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"cjbxochijwpsk\",\"dependencyConditions\":[]},{\"activity\":\"eprumhikwahbz\",\"dependencyConditions\":[]},{\"activity\":\"gwkimmvatrv\",\"dependencyConditions\":[]},{\"activity\":\"kxcrxqpenkujxdn\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"eterjerhwgiuduw\",\"value\":\"dataqytppjdyikdykxh\"}],\"\":{\"kmmcvftijl\":\"datadtucyutrpdgm\",\"aednczvnwyfzavsa\":\"datahlcrjynef\",\"yxhfejtywluxysm\":\"databahs\",\"m\":\"dataeeodfplwf\"}},{\"type\":\"Activity\",\"name\":\"bwwphjw\",\"description\":\"caofxgwyvjefnlxq\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"jxkxjrttzhna\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"qynwqcov\",\"value\":\"datajvrsurqhhbddxko\"},{\"name\":\"orcmayqas\",\"value\":\"datavepld\"},{\"name\":\"fxmpyvlfujsbcfog\",\"value\":\"dataubqcqnch\"}],\"\":{\"knblb\":\"datajug\"}}]},{\"value\":\"xv\",\"activities\":[{\"type\":\"Activity\",\"name\":\"svprumttrvkhu\",\"description\":\"txxwbjbanlmpm\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"xplrtueg\",\"dependencyConditions\":[]},{\"activity\":\"hqulnjeybgpjy\",\"dependencyConditions\":[]},{\"activity\":\"vjuowkt\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"vhdk\",\"value\":\"datadqcgedipnnzmvt\"},{\"name\":\"ttjmdtfuwx\",\"value\":\"dataee\"},{\"name\":\"omiesgur\",\"value\":\"datac\"}],\"\":{\"p\":\"datatumttmixe\",\"hvqnkwjhjut\":\"datarbazgou\",\"dflgqso\":\"dataxggn\",\"petsxetneher\":\"datauncmuvfukl\"}},{\"type\":\"Activity\",\"name\":\"belms\",\"description\":\"xhkzcdni\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"vgydtdtomknzotm\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"kwpooaskflrqwfmb\",\"value\":\"datakshb\"},{\"name\":\"zvnouthbvvcbwudi\",\"value\":\"datafix\"},{\"name\":\"w\",\"value\":\"datarqivqzqcmrxh\"},{\"name\":\"lozg\",\"value\":\"datafhijcetcystrs\"}],\"\":{\"rlrq\":\"datatxspaafseqoyo\"}},{\"type\":\"Activity\",\"name\":\"q\",\"description\":\"hulgtqveumwbmqp\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"jqkykjzbxmgsxb\",\"dependencyConditions\":[]},{\"activity\":\"ckambdoqfeobkm\",\"dependencyConditions\":[]},{\"activity\":\"ohmrb\",\"dependencyConditions\":[]},{\"activity\":\"h\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"xnwcejczi\",\"value\":\"dataf\"},{\"name\":\"daq\",\"value\":\"datankjyfy\"}],\"\":{\"ofhu\":\"datatiugcaashgr\",\"yjaxkbyo\":\"datauokrkibnonuocmx\",\"zxhtvythpynlmfvq\":\"datawtpmyvasnmzsvdrr\"}},{\"type\":\"Activity\",\"name\":\"yzacjxczjosixter\",\"description\":\"jkhtmmkmezlhmt\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"aynhz\",\"dependencyConditions\":[]},{\"activity\":\"ziwxwwpitwle\",\"dependencyConditions\":[]},{\"activity\":\"uq\",\"dependencyConditions\":[]}],\"userProperties\":[{\"name\":\"photb\",\"value\":\"datagkliu\"},{\"name\":\"txfzhvxqotwcfbqz\",\"value\":\"datazchpjh\"},{\"name\":\"hyxxftrfwmxwjc\",\"value\":\"dataxqkm\"},{\"name\":\"nauleofdxzno\",\"value\":\"datakdoffeu\"}],\"\":{\"jf\":\"datagnugiiyc\"}}]}],\"defaultActivities\":[{\"type\":\"Activity\",\"name\":\"tdynbrf\",\"description\":\"rabr\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"lz\",\"dependencyConditions\":[\"Completed\",\"Failed\"],\"\":{\"bgfz\":\"dataub\",\"tuzgceuzhp\":\"dataixyx\",\"vxpfayophpu\":\"datamnpodsqil\",\"hbqvbute\":\"datacca\"}},{\"activity\":\"xufrwiivekrgvzjt\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"tjnktheh\":\"datalweozccdo\",\"v\":\"datamijraei\",\"lbnroxgwqgbv\":\"datahhci\",\"bztwkz\":\"datactcbmnecozvx\"}},{\"activity\":\"puwjvju\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Completed\",\"Skipped\"],\"\":{\"jxjnxznlx\":\"datauxtyvpvegxdzopfk\",\"b\":\"datajkteubntqvlktq\",\"jiktwfjyl\":\"dataurblbtvsxnaothlr\",\"nwegyhzucpixfdbi\":\"datammibaowclb\"}},{\"activity\":\"pchbcbdpyorhq\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"nhszmuvareakcxda\":\"datanhyxcw\",\"npcrsfqwqm\":\"datanmnmqydpieleruoy\",\"vjurjczdelqaz\":\"dataisjqo\"}}],\"userProperties\":[{\"name\":\"xg\",\"value\":\"datarkbhwwpaec\"}],\"\":{\"gdb\":\"dataqacaedvnloqjmo\",\"jksmyeegbertf\":\"databrrqxldkhgngyofe\",\"rd\":\"datancxkazmydsqvjkfz\",\"bw\":\"datacwgcmmv\"}}]}")
.toObject(SwitchActivityTypeProperties.class);
- Assertions.assertEquals("wqyhklhossc", model.on().value());
- Assertions.assertEquals("ungjb", model.cases().get(0).value());
- Assertions.assertEquals("sjgmes", model.cases().get(0).activities().get(0).name());
- Assertions.assertEquals("hxkjjhflrg", model.cases().get(0).activities().get(0).description());
+ Assertions.assertEquals("niybotuq", model.on().value());
+ Assertions.assertEquals("uqvterbsgwoyk", model.cases().get(0).value());
+ Assertions.assertEquals("qyfixwgqmxm", model.cases().get(0).activities().get(0).name());
+ Assertions.assertEquals("fzr", model.cases().get(0).activities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.cases().get(0).activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED,
model.cases().get(0).activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("dgqpbgzyaf", model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals("zbvdzjlkocjuajcl",
+ Assertions.assertEquals("bnvqu", model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("kwbsttmvaijn",
model.cases().get(0).activities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("kfzi", model.defaultActivities().get(0).name());
- Assertions.assertEquals("bwthvww", model.defaultActivities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.defaultActivities().get(0).state());
+ Assertions.assertEquals("tdynbrf", model.defaultActivities().get(0).name());
+ Assertions.assertEquals("rabr", model.defaultActivities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.defaultActivities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.defaultActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("fgpj", model.defaultActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("lz", model.defaultActivities().get(0).dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED,
model.defaultActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("bjbknpzhfhi", model.defaultActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("xg", model.defaultActivities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
SwitchActivityTypeProperties model = new SwitchActivityTypeProperties()
- .withOn(new Expression().withValue("wqyhklhossc"))
- .withCases(Arrays.asList(new SwitchCase().withValue("ungjb")
- .withActivities(Arrays.asList(new Activity().withName("sjgmes")
- .withDescription("hxkjjhflrg")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("dgqpbgzyaf")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("zwieizzxjjdb")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("xuinrsrrijcwn")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("htqtbcwtcqjsvlzd")
- .withDependencyConditions(Arrays.asList())
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("zbvdzjlkocjuajcl").withValue("datatssbkzdgwpyljn"),
- new UserProperty().withName("iprjahgqzb").withValue("dataicyufnum")))
- .withAdditionalProperties(mapOf("type", "Activity"))))))
- .withDefaultActivities(Arrays.asList(
- new Activity().withName("kfzi")
- .withDescription("bwthvww")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("fgpj")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.FAILED, DependencyCondition.FAILED, DependencyCondition.SKIPPED))
+ .withOn(new Expression().withValue("niybotuq"))
+ .withCases(Arrays.asList(
+ new SwitchCase().withValue("uqvterbsgwoyk")
+ .withActivities(Arrays.asList(
+ new Activity().withName("qyfixwgqmxm")
+ .withDescription("fzr")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("bnvqu")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("kwbsttmvaijn").withValue("dataqnqwkaevbg"),
+ new UserProperty().withName("hmyzsqovmtid").withValue("dataycyyajl"),
+ new UserProperty().withName("otmir").withValue("dataipnclnbfxme")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("kceyjtdeyoxtlqyt")
+ .withDescription("tepzrcqnsjqrgtap")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("mwbtr")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("kl")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ndb")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("lqtpebaa")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("xpy").withValue("databjtjvqdwzyvxdg"),
+ new UserProperty().withName("enieqlikyc").withValue("dataunfuk")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("uortgwwtaolfdgjr")
+ .withDescription("hpvohvcaq")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("na")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("ueqouzjgvqz").withValue("dataihtn"),
+ new UserProperty().withName("adrmt").withValue("datahfxy"),
+ new UserProperty().withName("nn").withValue("dataazbfrqo"),
+ new UserProperty().withName("igxndfrxnvwqy").withValue("datakl")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("bcwtcqjsvlzdus")
+ .withDescription("b")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("cjuajclrtssbk")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("dgwpyljn")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("rjah").withValue("dataq"),
+ new UserProperty().withName("byic").withValue("dataufnumf")))
+ .withAdditionalProperties(mapOf("type", "Activity")))),
+ new SwitchCase().withValue("ossqm")
+ .withActivities(Arrays.asList(
+ new Activity().withName("bvfa")
+ .withDescription("pobzvxntsfyntkfz")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("vwwhmldsn")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("pjkk").withValue("dataaenzuuf"),
+ new UserProperty().withName("d").withValue("dataknxep"),
+ new UserProperty().withName("wxdwlo").withValue("dataymeqiqnjcajmxu"),
+ new UserProperty().withName("xkvpleooom").withValue("dataqdjfldzvgo")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("je")
+ .withDescription("jbknpzhfhibhgwb")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("cjbxochijwpsk")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("eprumhikwahbz")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("gwkimmvatrv")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("kxcrxqpenkujxdn")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("eterjerhwgiuduw").withValue("dataqytppjdyikdykxh")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("bwwphjw")
+ .withDescription("caofxgwyvjefnlxq")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("jxkxjrttzhna")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("qynwqcov").withValue("datajvrsurqhhbddxko"),
+ new UserProperty().withName("orcmayqas").withValue("datavepld"),
+ new UserProperty().withName("fxmpyvlfujsbcfog").withValue("dataubqcqnch")))
+ .withAdditionalProperties(mapOf("type", "Activity")))),
+ new SwitchCase().withValue("xv")
+ .withActivities(Arrays.asList(
+ new Activity().withName("svprumttrvkhu")
+ .withDescription("txxwbjbanlmpm")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("xplrtueg")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("hqulnjeybgpjy")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("vjuowkt")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("vhdk").withValue("datadqcgedipnnzmvt"),
+ new UserProperty().withName("ttjmdtfuwx").withValue("dataee"),
+ new UserProperty().withName("omiesgur").withValue("datac")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("belms")
+ .withDescription("xhkzcdni")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("vgydtdtomknzotm")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("kwpooaskflrqwfmb").withValue("datakshb"),
+ new UserProperty().withName("zvnouthbvvcbwudi").withValue("datafix"),
+ new UserProperty().withName("w").withValue("datarqivqzqcmrxh"),
+ new UserProperty().withName("lozg").withValue("datafhijcetcystrs")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("q")
+ .withDescription("hulgtqveumwbmqp")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("jqkykjzbxmgsxb")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ckambdoqfeobkm")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ohmrb")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("h")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("xnwcejczi").withValue("dataf"),
+ new UserProperty().withName("daq").withValue("datankjyfy")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("yzacjxczjosixter")
+ .withDescription("jkhtmmkmezlhmt")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("aynhz")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("ziwxwwpitwle")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("uq")
+ .withDependencyConditions(Arrays.asList())
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("photb").withValue("datagkliu"),
+ new UserProperty().withName("txfzhvxqotwcfbqz").withValue("datazchpjh"),
+ new UserProperty().withName("hyxxftrfwmxwjc").withValue("dataxqkm"),
+ new UserProperty().withName("nauleofdxzno").withValue("datakdoffeu")))
+ .withAdditionalProperties(mapOf("type", "Activity"))))))
+ .withDefaultActivities(Arrays.asList(new Activity().withName("tdynbrf")
+ .withDescription("rabr")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("lz")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("xufrwiivekrgvzjt")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("puwjvju")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("pchbcbdpyorhq")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("bjbknpzhfhi").withValue("datahgwbslrqbd"),
- new UserProperty().withName("cjbxochijwpsk")
- .withValue("dataeprumhikwahbz"),
- new UserProperty().withName("gwkimmvatrv").withValue("datakxcrxqpenkujxdn")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("rkdtucyutrp")
- .withDescription("mukmmcvfti")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("jynefxaed")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("ambjqynwqcov")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.FAILED, DependencyCondition.SKIPPED, DependencyCondition.SKIPPED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("a").withValue("dataxmpyvlfujsbcfogu"),
- new UserProperty().withName("bqcqnchdzyju").withValue("datadknblbrixvcp"),
- new UserProperty().withName("svprumttrvkhu").withValue("dataxtx"),
- new UserProperty().withName("w").withValue("datajbanlmpmvegxgymx")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ .withUserProperties(Arrays.asList(new UserProperty().withName("xg").withValue("datarkbhwwpaec")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(SwitchActivityTypeProperties.class);
- Assertions.assertEquals("wqyhklhossc", model.on().value());
- Assertions.assertEquals("ungjb", model.cases().get(0).value());
- Assertions.assertEquals("sjgmes", model.cases().get(0).activities().get(0).name());
- Assertions.assertEquals("hxkjjhflrg", model.cases().get(0).activities().get(0).description());
+ Assertions.assertEquals("niybotuq", model.on().value());
+ Assertions.assertEquals("uqvterbsgwoyk", model.cases().get(0).value());
+ Assertions.assertEquals("qyfixwgqmxm", model.cases().get(0).activities().get(0).name());
+ Assertions.assertEquals("fzr", model.cases().get(0).activities().get(0).description());
Assertions.assertEquals(ActivityState.ACTIVE, model.cases().get(0).activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED,
model.cases().get(0).activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("dgqpbgzyaf", model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals("zbvdzjlkocjuajcl",
+ Assertions.assertEquals("bnvqu", model.cases().get(0).activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("kwbsttmvaijn",
model.cases().get(0).activities().get(0).userProperties().get(0).name());
- Assertions.assertEquals("kfzi", model.defaultActivities().get(0).name());
- Assertions.assertEquals("bwthvww", model.defaultActivities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.defaultActivities().get(0).state());
+ Assertions.assertEquals("tdynbrf", model.defaultActivities().get(0).name());
+ Assertions.assertEquals("rabr", model.defaultActivities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.defaultActivities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.defaultActivities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("fgpj", model.defaultActivities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals("lz", model.defaultActivities().get(0).dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED,
model.defaultActivities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("bjbknpzhfhi", model.defaultActivities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("xg", model.defaultActivities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchCaseTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchCaseTests.java
index 89af3a5c4562..18b42a27ebe5 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchCaseTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SwitchCaseTests.java
@@ -21,118 +21,101 @@ public final class SwitchCaseTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SwitchCase model = BinaryData.fromString(
- "{\"value\":\"mies\",\"activities\":[{\"type\":\"Activity\",\"name\":\"pcwpbtumttmixe\",\"description\":\"arb\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"vqnkwjhj\",\"dependencyConditions\":[\"Failed\",\"Succeeded\"],\"\":{\"uvfuklepe\":\"datanldflgqsoiunc\",\"etneherqbel\":\"datas\",\"nxhkzc\":\"datas\"}},{\"activity\":\"nipjtduvsvgydtd\",\"dependencyConditions\":[\"Failed\"],\"\":{\"pooaskflrqwfmbk\":\"datazotmiizk\",\"bwudiyfixpwrrqiv\":\"datashbrzvnouthbvv\",\"lozg\":\"datazqcmrxh\",\"yttxspaafs\":\"datafhijcetcystrs\"}},{\"activity\":\"qoyoerlrqtqnx\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"e\":\"dataq\",\"kjzbxmgsxbk\":\"datamwbmqpbfjbsoljqk\",\"eobkmx\":\"datakambdoq\",\"ldxnw\":\"datahmrbjh\"}}],\"userProperties\":[{\"name\":\"czikfx\",\"value\":\"dataaqwnkjyfy\"},{\"name\":\"mbtiugc\",\"value\":\"dataashgryofhuv\"}],\"\":{\"b\":\"datark\",\"jaxkby\":\"dataonuocmxt\"}},{\"type\":\"Activity\",\"name\":\"v\",\"description\":\"pmyvasn\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"yz\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Failed\"],\"\":{\"lmfvqvyzacjxczj\":\"datapy\"}},{\"activity\":\"sixterpbjkhtmm\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Failed\"],\"\":{\"mziwxwwpi\":\"datatrqhncscaynh\"}},{\"activity\":\"wl\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Succeeded\",\"Failed\"],\"\":{\"txfzhvxqotwcfbqz\":\"datahotbsgkliu\",\"hyxxftrfwmxwjc\":\"datazchpjh\"}}],\"userProperties\":[{\"name\":\"kmona\",\"value\":\"dataleof\"},{\"name\":\"xznopk\",\"value\":\"dataoffeutvqgnugiiyc\"},{\"name\":\"jf\",\"value\":\"datakntdynbrf\"},{\"name\":\"crabrqdbxhg\",\"value\":\"datalz\"}],\"\":{\"fziixyxntuz\":\"datavnlubkb\",\"pcmnpo\":\"dataceuz\",\"fayophpudccaqhb\":\"datasqilmvx\",\"rgvzjtvjrrk\":\"datavbutesxufrwiive\"}},{\"type\":\"Activity\",\"name\":\"lweozccdo\",\"description\":\"jnkthehjmij\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"hhci\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Failed\"],\"\":{\"ctcbmnecozvx\":\"datagwqgbv\",\"puwjvju\":\"databztwkz\",\"xdzopfkz\":\"dataxbtkuviuxtyvpve\"}},{\"activity\":\"xjnxznlx\",\"dependencyConditions\":[\"Completed\",\"Completed\",\"Completed\",\"Failed\"],\"\":{\"ktqsbmurb\":\"datatqv\",\"o\":\"databtvsxn\",\"wfjylhmmibaowc\":\"datahlrhjik\"}},{\"activity\":\"bznwegyhzucpixfd\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Failed\"],\"\":{\"hyx\":\"datacbdpyorhqbpfvh\"}},{\"activity\":\"wsnhszmuvarea\",\"dependencyConditions\":[\"Skipped\",\"Completed\"],\"\":{\"npcrsfqwqm\":\"datanmnmqydpieleruoy\"}}],\"userProperties\":[{\"name\":\"j\",\"value\":\"dataonvjur\"},{\"name\":\"czdelqazb\",\"value\":\"dataixg\"}],\"\":{\"uvqacae\":\"databhwwpaec\",\"oqjmo\":\"datavn\",\"brrqxldkhgngyofe\":\"datagdb\",\"ncxkazmydsqvjkfz\":\"datajksmyeegbertf\"}},{\"type\":\"Activity\",\"name\":\"rd\",\"description\":\"wgcmmvvbwrilcyep\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"jkdacuvyec\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Completed\"],\"\":{\"dfy\":\"datalbx\",\"wmehaic\":\"dataywmezoi\",\"v\":\"datakkcpkvujwf\",\"fsiiadfjxfiv\":\"datavvnbbeys\"}}],\"userProperties\":[{\"name\":\"gpt\",\"value\":\"dataxilwnvfb\"}],\"\":{\"kazlekjh\":\"datao\",\"hhkcutxmq\":\"dataawiitxyebidkn\"}}]}")
+ "{\"value\":\"lcyepqtdvgd\",\"activities\":[{\"type\":\"Activity\",\"name\":\"dacuvyeckbudepul\",\"description\":\"gdfyhywmezoiywme\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"cp\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Succeeded\"],\"\":{\"vvnbbeys\":\"datav\",\"uq\":\"datafsiiadfjxfiv\",\"toqka\":\"dataptzxilwnvfbr\",\"huawiit\":\"datalek\"}},{\"activity\":\"yeb\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Completed\"],\"\":{\"duu\":\"datakcutxmqvbhfb\",\"k\":\"datakrskqgokhpzvph\",\"mhrfwch\":\"datafcxvfurkdhopz\"}}],\"userProperties\":[{\"name\":\"eovji\",\"value\":\"datazkwdexldocq\"},{\"name\":\"lbsvyokiexmfe\",\"value\":\"datachltxayqwfu\"},{\"name\":\"vo\",\"value\":\"datae\"}],\"\":{\"nochnmx\":\"datacgzifogbmeksegdj\",\"knazc\":\"datahgsimenjht\"}},{\"type\":\"Activity\",\"name\":\"ja\",\"description\":\"vnollpz\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"quiqkuxajl\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Skipped\"],\"\":{\"bnmaiq\":\"datarnowexfykdirc\",\"jrxoi\":\"datajoirxngmm\"}},{\"activity\":\"mnsmdsmzkjlh\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Succeeded\"],\"\":{\"medyb\":\"databyfiochf\"}}],\"userProperties\":[{\"name\":\"zoae\",\"value\":\"datadhvszwgmpzbxqf\"}],\"\":{\"lqnrds\":\"datapwglkvspbdjushzf\",\"wewgda\":\"datarvp\",\"dlilkw\":\"datahzdhszk\"}},{\"type\":\"Activity\",\"name\":\"zmyvdabgctm\",\"description\":\"tlrfxnokpkgr\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"hdkx\",\"dependencyConditions\":[\"Skipped\",\"Failed\",\"Succeeded\",\"Failed\"],\"\":{\"rchnrhg\":\"datakd\",\"hluoyr\":\"datalsvosvqj\",\"hzpwsadwsent\":\"datahqq\",\"qvd\":\"datacdzyvxwnmiumduw\"}},{\"activity\":\"uvxmrbbgl\",\"dependencyConditions\":[\"Completed\",\"Skipped\",\"Completed\",\"Skipped\"],\"\":{\"tywzrnxiktok\":\"datana\",\"cfprioabqxwid\":\"dataptxmdadfygj\"}},{\"activity\":\"xeonnolrsmxt\",\"dependencyConditions\":[\"Failed\",\"Skipped\",\"Succeeded\"],\"\":{\"uotexlpqydgfzet\":\"dataaxmo\"}}],\"userProperties\":[{\"name\":\"mnseigoalxwuq\",\"value\":\"dataczrskdovgkpq\"},{\"name\":\"zrxhghsmlxogim\",\"value\":\"datahxyx\"},{\"name\":\"lxawixdcy\",\"value\":\"datadqamiy\"}],\"\":{\"zco\":\"datazlbcamdzoauvwjkg\",\"aqxztywzaq\":\"datawcnnzacqludq\",\"zlzpowsefpg\":\"datafqtstmyfebb\",\"pzbsytwt\":\"dataw\"}},{\"type\":\"Activity\",\"name\":\"vcdtsvgyzmafq\",\"description\":\"wupuubyvwejy\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"hrxoekyf\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"jxjaaocjlwco\":\"datapdgnsmhrpzbyudko\",\"vmzxrhve\":\"datawcrextdymkzbliu\",\"guvqghuehgcqhlfq\":\"datangzjxjbklta\",\"r\":\"datamjldeluqqnf\"}}],\"userProperties\":[{\"name\":\"luomaltvvp\",\"value\":\"datadhtdapkdahyn\"},{\"name\":\"tixrkjogyqrmt\",\"value\":\"dataiclsxuibyfylhf\"}],\"\":{\"cwuz\":\"dataauqylmlunquvlva\",\"gynqedn\":\"datalx\",\"qcxzdlfs\":\"dataidacskul\"}}]}")
.toObject(SwitchCase.class);
- Assertions.assertEquals("mies", model.value());
- Assertions.assertEquals("pcwpbtumttmixe", model.activities().get(0).name());
- Assertions.assertEquals("arb", model.activities().get(0).description());
+ Assertions.assertEquals("lcyepqtdvgd", model.value());
+ Assertions.assertEquals("dacuvyeckbudepul", model.activities().get(0).name());
+ Assertions.assertEquals("gdfyhywmezoiywme", model.activities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("vqnkwjhj", model.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("cp", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("czikfx", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("eovji", model.activities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SwitchCase model
- = new SwitchCase().withValue("mies")
- .withActivities(
- Arrays
- .asList(
- new Activity().withName("pcwpbtumttmixe")
- .withDescription("arb")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(
- Arrays.asList(
- new ActivityDependency().withActivity("vqnkwjhj")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("nipjtduvsvgydtd")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("qoyoerlrqtqnx")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("czikfx").withValue("dataaqwnkjyfy"),
- new UserProperty().withName("mbtiugc").withValue("dataashgryofhuv")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("v")
- .withDescription("pmyvasn")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
- .withDependsOn(
- Arrays.asList(
- new ActivityDependency().withActivity("yz")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("sixterpbjkhtmm")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
- DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wl")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED,
- DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("kmona").withValue("dataleof"),
- new UserProperty().withName("xznopk").withValue("dataoffeutvqgnugiiyc"),
- new UserProperty().withName("jf").withValue("datakntdynbrf"),
- new UserProperty().withName("crabrqdbxhg").withValue("datalz")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("lweozccdo")
- .withDescription("jnkthehjmij")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("hhci")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("xjnxznlx")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED,
- DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("bznwegyhzucpixfd")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("wsnhszmuvarea")
- .withDependencyConditions(
- Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("j").withValue("dataonvjur"),
- new UserProperty().withName("czdelqazb").withValue("dataixg")))
- .withAdditionalProperties(mapOf("type", "Activity")),
- new Activity().withName("rd")
- .withDescription("wgcmmvvbwrilcyep")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("jkdacuvyec")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.SKIPPED, DependencyCondition.COMPLETED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("gpt").withValue("dataxilwnvfb")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ SwitchCase model = new SwitchCase().withValue("lcyepqtdvgd")
+ .withActivities(Arrays.asList(
+ new Activity().withName("dacuvyeckbudepul")
+ .withDescription("gdfyhywmezoiywme")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("cp")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("yeb")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.FAILED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("eovji").withValue("datazkwdexldocq"),
+ new UserProperty().withName("lbsvyokiexmfe").withValue("datachltxayqwfu"),
+ new UserProperty().withName("vo").withValue("datae")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("ja")
+ .withDescription("vnollpz")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("quiqkuxajl")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("mnsmdsmzkjlh")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("zoae").withValue("datadhvszwgmpzbxqf")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("zmyvdabgctm")
+ .withDescription("tlrfxnokpkgr")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("hdkx")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.FAILED, DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("uvxmrbbgl")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SKIPPED,
+ DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("xeonnolrsmxt")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("mnseigoalxwuq").withValue("dataczrskdovgkpq"),
+ new UserProperty().withName("zrxhghsmlxogim").withValue("datahxyx"),
+ new UserProperty().withName("lxawixdcy").withValue("datadqamiy")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("vcdtsvgyzmafq")
+ .withDescription("wupuubyvwejy")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("hrxoekyf")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("luomaltvvp").withValue("datadhtdapkdahyn"),
+ new UserProperty().withName("tixrkjogyqrmt").withValue("dataiclsxuibyfylhf")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(SwitchCase.class);
- Assertions.assertEquals("mies", model.value());
- Assertions.assertEquals("pcwpbtumttmixe", model.activities().get(0).name());
- Assertions.assertEquals("arb", model.activities().get(0).description());
+ Assertions.assertEquals("lcyepqtdvgd", model.value());
+ Assertions.assertEquals("dacuvyeckbudepul", model.activities().get(0).name());
+ Assertions.assertEquals("gdfyhywmezoiywme", model.activities().get(0).description());
Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("vqnkwjhj", model.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED,
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("cp", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("czikfx", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("eovji", model.activities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseSourceTests.java
index bbe363c8f55b..abc3babf9e0a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseSourceTests.java
@@ -11,19 +11,19 @@ public final class SybaseSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SybaseSource model = BinaryData.fromString(
- "{\"type\":\"SybaseSource\",\"query\":\"dataa\",\"queryTimeout\":\"databnekhjzbfb\",\"additionalColumns\":\"dataeqkuozarr\",\"sourceRetryCount\":\"datapyzryjb\",\"sourceRetryWait\":\"databcvoyqnrjdrc\",\"maxConcurrentConnections\":\"datarvzewogh\",\"disableMetricsCollection\":\"datazxkjqecj\",\"\":{\"igpistpx\":\"dataomeawthyc\",\"wlaw\":\"datazjnparsulm\",\"xxqgoavzycxpza\":\"datakhe\",\"mftmxwtwzs\":\"datatalo\"}}")
+ "{\"type\":\"SybaseSource\",\"query\":\"datablucpmqwkfgmkp\",\"queryTimeout\":\"datakstzqz\",\"additionalColumns\":\"datawrcajfers\",\"sourceRetryCount\":\"dataxlkcw\",\"sourceRetryWait\":\"dataejssksgxykdepqcy\",\"maxConcurrentConnections\":\"datahwsxpzkmotgmd\",\"disableMetricsCollection\":\"datawwqevbiuntp\",\"\":{\"qgywr\":\"datawjxlycelf\",\"ruldt\":\"datau\"}}")
.toObject(SybaseSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SybaseSource model = new SybaseSource().withSourceRetryCount("datapyzryjb")
- .withSourceRetryWait("databcvoyqnrjdrc")
- .withMaxConcurrentConnections("datarvzewogh")
- .withDisableMetricsCollection("datazxkjqecj")
- .withQueryTimeout("databnekhjzbfb")
- .withAdditionalColumns("dataeqkuozarr")
- .withQuery("dataa");
+ SybaseSource model = new SybaseSource().withSourceRetryCount("dataxlkcw")
+ .withSourceRetryWait("dataejssksgxykdepqcy")
+ .withMaxConcurrentConnections("datahwsxpzkmotgmd")
+ .withDisableMetricsCollection("datawwqevbiuntp")
+ .withQueryTimeout("datakstzqz")
+ .withAdditionalColumns("datawrcajfers")
+ .withQuery("datablucpmqwkfgmkp");
model = BinaryData.fromObject(model).toObject(SybaseSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTests.java
index d64a1ac88199..4040ed36125a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTests.java
@@ -19,32 +19,32 @@ public final class SybaseTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SybaseTableDataset model = BinaryData.fromString(
- "{\"type\":\"SybaseTable\",\"typeProperties\":{\"tableName\":\"datacrolrzesbomp\"},\"description\":\"kymunwjivtb\",\"structure\":\"datazbdjrdfeujywdal\",\"schema\":\"datadeqngc\",\"linkedServiceName\":{\"referenceName\":\"ydzin\",\"parameters\":{\"xrsi\":\"dataulpozmdahyc\",\"oiaf\":\"dataoebld\",\"x\":\"datajkrtnhrevimxm\"}},\"parameters\":{\"oqtbfkvuozbzc\":{\"type\":\"Object\",\"defaultValue\":\"datatygvdwd\"},\"rlcydjht\":{\"type\":\"Object\",\"defaultValue\":\"dataekwanklp\"}},\"annotations\":[\"dataerwi\",\"datandurdonkgobxbl\",\"datadolenrsw\",\"datanpdrgnmzaofroe\"],\"folder\":{\"name\":\"kievyrej\"},\"\":{\"ftusdwmnrt\":\"databk\",\"nrovome\":\"datavbuc\"}}")
+ "{\"type\":\"SybaseTable\",\"typeProperties\":{\"tableName\":\"datatxa\"},\"description\":\"ujdbq\",\"structure\":\"datayexb\",\"schema\":\"datagxqqqasfeooqftp\",\"linkedServiceName\":{\"referenceName\":\"evtarphklqlii\",\"parameters\":{\"wgjnofgij\":\"datan\",\"zmwyw\":\"datadgsebjuymtevae\",\"edogzougxbxx\":\"datarjkejv\"}},\"parameters\":{\"mtenfdvdoe\":{\"type\":\"String\",\"defaultValue\":\"dataphivfh\"}},\"annotations\":[\"datawusrjzhdt\",\"datasyfezfsmyljd\",\"datayyrwnmwtqi\"],\"folder\":{\"name\":\"nnkynkstd\"},\"\":{\"wvaosckfavhk\":\"datahjfphfxaqjyihjc\",\"weifdyfa\":\"datapsp\"}}")
.toObject(SybaseTableDataset.class);
- Assertions.assertEquals("kymunwjivtb", model.description());
- Assertions.assertEquals("ydzin", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("oqtbfkvuozbzc").type());
- Assertions.assertEquals("kievyrej", model.folder().name());
+ Assertions.assertEquals("ujdbq", model.description());
+ Assertions.assertEquals("evtarphklqlii", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("mtenfdvdoe").type());
+ Assertions.assertEquals("nnkynkstd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SybaseTableDataset model = new SybaseTableDataset().withDescription("kymunwjivtb")
- .withStructure("datazbdjrdfeujywdal")
- .withSchema("datadeqngc")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ydzin")
- .withParameters(mapOf("xrsi", "dataulpozmdahyc", "oiaf", "dataoebld", "x", "datajkrtnhrevimxm")))
- .withParameters(mapOf("oqtbfkvuozbzc",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datatygvdwd"), "rlcydjht",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("dataekwanklp")))
- .withAnnotations(Arrays.asList("dataerwi", "datandurdonkgobxbl", "datadolenrsw", "datanpdrgnmzaofroe"))
- .withFolder(new DatasetFolder().withName("kievyrej"))
- .withTableName("datacrolrzesbomp");
+ SybaseTableDataset model = new SybaseTableDataset().withDescription("ujdbq")
+ .withStructure("datayexb")
+ .withSchema("datagxqqqasfeooqftp")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("evtarphklqlii")
+ .withParameters(
+ mapOf("wgjnofgij", "datan", "zmwyw", "datadgsebjuymtevae", "edogzougxbxx", "datarjkejv")))
+ .withParameters(mapOf("mtenfdvdoe",
+ new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataphivfh")))
+ .withAnnotations(Arrays.asList("datawusrjzhdt", "datasyfezfsmyljd", "datayyrwnmwtqi"))
+ .withFolder(new DatasetFolder().withName("nnkynkstd"))
+ .withTableName("datatxa");
model = BinaryData.fromObject(model).toObject(SybaseTableDataset.class);
- Assertions.assertEquals("kymunwjivtb", model.description());
- Assertions.assertEquals("ydzin", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("oqtbfkvuozbzc").type());
- Assertions.assertEquals("kievyrej", model.folder().name());
+ Assertions.assertEquals("ujdbq", model.description());
+ Assertions.assertEquals("evtarphklqlii", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.STRING, model.parameters().get("mtenfdvdoe").type());
+ Assertions.assertEquals("nnkynkstd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTypePropertiesTests.java
index 56e850d0e977..e5e49a4bf53d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SybaseTableDatasetTypePropertiesTests.java
@@ -10,13 +10,13 @@
public final class SybaseTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- SybaseTableDatasetTypeProperties model = BinaryData.fromString("{\"tableName\":\"datawsicvwqzoc\"}")
- .toObject(SybaseTableDatasetTypeProperties.class);
+ SybaseTableDatasetTypeProperties model
+ = BinaryData.fromString("{\"tableName\":\"dataxnguwn\"}").toObject(SybaseTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SybaseTableDatasetTypeProperties model = new SybaseTableDatasetTypeProperties().withTableName("datawsicvwqzoc");
+ SybaseTableDatasetTypeProperties model = new SybaseTableDatasetTypeProperties().withTableName("dataxnguwn");
model = BinaryData.fromObject(model).toObject(SybaseTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTests.java
index fce11fb8ad30..7d902d7451ef 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTests.java
@@ -31,89 +31,85 @@ public final class SynapseNotebookActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SynapseNotebookActivity model = BinaryData.fromString(
- "{\"type\":\"SynapseNotebook\",\"typeProperties\":{\"notebook\":{\"type\":\"NotebookReference\",\"referenceName\":\"datafroynfloam\"},\"sparkPool\":{\"type\":\"BigDataPoolReference\",\"referenceName\":\"datafiivgdsnrknikp\"},\"parameters\":{\"hmfbzkfehrslvofn\":{\"value\":\"dataqnxyloyclrle\",\"type\":\"float\"},\"ahsqo\":{\"value\":\"datawsuroddohng\",\"type\":\"float\"},\"kdmnvaibh\":{\"value\":\"dataandslrndius\",\"type\":\"bool\"},\"ssweznzfdext\":{\"value\":\"datajg\",\"type\":\"string\"}},\"executorSize\":\"datarnhpxzjk\",\"conf\":\"datavzpcecisnhtds\",\"driverSize\":\"datanigohafud\",\"numExecutors\":\"datao\",\"configurationType\":\"Default\",\"targetSparkConfiguration\":{\"type\":\"SparkConfigurationReference\",\"referenceName\":\"dataqgrcnf\"},\"sparkConfig\":{\"vfzl\":\"datagjvl\",\"j\":\"dataugxpugetw\"}},\"linkedServiceName\":{\"referenceName\":\"dddvfnqazvavsp\",\"parameters\":{\"lkyrssyy\":\"dataaytzkdqimumaijcu\",\"rvrx\":\"dataedzhnyl\",\"jsqazecdomjrrolw\":\"datakpl\"}},\"policy\":{\"timeout\":\"datacaqxstykusfqmgj\",\"retry\":\"dataiqejvpdrcnoe\",\"retryIntervalInSeconds\":730397817,\"secureInput\":true,\"secureOutput\":true,\"\":{\"zyycev\":\"datar\",\"y\":\"dataazwewhobxlk\",\"nuxvyalkcuozwow\":\"dataspidcnxjfgx\",\"qlb\":\"datamulqgaeqnlx\"}},\"name\":\"ezcwfscxkrzuze\",\"description\":\"vxmkzg\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"sgebw\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"yahurxtpuyuradf\":\"dataguplzdoamqkdwag\",\"ivkmdfwfzkocdj\":\"datawjounvfqyk\",\"rbphtllkpkcqzbvy\":\"dataj\"}},{\"activity\":\"vfx\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\"],\"\":{\"ypevfrbujltg\":\"dataxrjidxio\",\"as\":\"datahgyl\",\"mhknsknnnpyo\":\"datawhbmo\"}}],\"userProperties\":[{\"name\":\"nyqsdsuewfgrijd\",\"value\":\"datakmcrtmvtfeyopg\"},{\"name\":\"iwebmcizmggvsxv\",\"value\":\"datawrqywaagzaxqh\"},{\"name\":\"erkyimcfmdhwtlli\",\"value\":\"datacyxcluvj\"}],\"\":{\"hshcjgoobltoar\":\"datajpld\",\"fsmabuur\":\"datacntgqyqwmzzcgbg\",\"hf\":\"datauqwvybxmu\"}}")
+ "{\"type\":\"SynapseNotebook\",\"typeProperties\":{\"notebook\":{\"type\":\"NotebookReference\",\"referenceName\":\"datapfdhfp\"},\"sparkPool\":{\"type\":\"BigDataPoolReference\",\"referenceName\":\"datahggaziaps\"},\"parameters\":{\"gmeiihabo\":{\"value\":\"datamieheqmtet\",\"type\":\"string\"}},\"executorSize\":\"datargetnc\",\"conf\":\"datajwjrpljkcqed\",\"driverSize\":\"dataeefzlwohobaaccg\",\"numExecutors\":\"datai\",\"configurationType\":\"Artifact\",\"targetSparkConfiguration\":{\"type\":\"SparkConfigurationReference\",\"referenceName\":\"dataoeiqhbrdcgmyjm\"},\"sparkConfig\":{\"bzvink\":\"datakpbrr\"}},\"linkedServiceName\":{\"referenceName\":\"eblrnu\",\"parameters\":{\"musudhjoshmmzotc\":\"datan\",\"difbeott\":\"dataffmik\"}},\"policy\":{\"timeout\":\"dataonejpjzqb\",\"retry\":\"datatv\",\"retryIntervalInSeconds\":148980075,\"secureInput\":false,\"secureOutput\":false,\"\":{\"bdqobngjbeihcaxk\":\"datalhnix\",\"vbcxnni\":\"datavr\"}},\"name\":\"nfuvesmepqrkjyp\",\"description\":\"vnotbenfshf\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"g\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Failed\"],\"\":{\"duodp\":\"datavm\",\"ggn\":\"datati\",\"pqwucprpw\":\"dataocqaejlebcy\"}},{\"activity\":\"g\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"aoc\":\"datakefwmqialebcto\",\"oyjdnzrcjokgthyd\":\"datapjsfhxhulrek\"}},{\"activity\":\"zrr\",\"dependencyConditions\":[\"Completed\"],\"\":{\"vyceks\":\"datasoivaoryefgw\"}}],\"userProperties\":[{\"name\":\"jtgmfjzqvi\",\"value\":\"datadhixd\"}],\"\":{\"yzjdrkcs\":\"datacsmcqskrjnqaa\",\"sfztlxqhyyxhzgx\":\"dataeox\"}}")
.toObject(SynapseNotebookActivity.class);
- Assertions.assertEquals("ezcwfscxkrzuze", model.name());
- Assertions.assertEquals("vxmkzg", model.description());
+ Assertions.assertEquals("nfuvesmepqrkjyp", model.name());
+ Assertions.assertEquals("vnotbenfshf", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("sgebw", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("nyqsdsuewfgrijd", model.userProperties().get(0).name());
- Assertions.assertEquals("dddvfnqazvavsp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(730397817, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
+ Assertions.assertEquals("g", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("jtgmfjzqvi", model.userProperties().get(0).name());
+ Assertions.assertEquals("eblrnu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(148980075, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(false, model.policy().secureOutput());
Assertions.assertEquals(NotebookReferenceType.NOTEBOOK_REFERENCE, model.notebook().type());
Assertions.assertEquals(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE, model.sparkPool().type());
- Assertions.assertEquals(NotebookParameterType.FLOAT, model.parameters().get("hmfbzkfehrslvofn").type());
- Assertions.assertEquals(ConfigurationType.DEFAULT, model.configurationType());
+ Assertions.assertEquals(NotebookParameterType.STRING, model.parameters().get("gmeiihabo").type());
+ Assertions.assertEquals(ConfigurationType.ARTIFACT, model.configurationType());
Assertions.assertEquals(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE,
model.targetSparkConfiguration().type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- SynapseNotebookActivity model = new SynapseNotebookActivity().withName("ezcwfscxkrzuze")
- .withDescription("vxmkzg")
+ SynapseNotebookActivity model = new SynapseNotebookActivity().withName("nfuvesmepqrkjyp")
+ .withDescription("vnotbenfshf")
.withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("sgebw")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("g")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED,
+ DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("vfx")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("g")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("zrr")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("nyqsdsuewfgrijd").withValue("datakmcrtmvtfeyopg"),
- new UserProperty().withName("iwebmcizmggvsxv").withValue("datawrqywaagzaxqh"),
- new UserProperty().withName("erkyimcfmdhwtlli").withValue("datacyxcluvj")))
- .withLinkedServiceName(
- new LinkedServiceReference().withReferenceName("dddvfnqazvavsp")
- .withParameters(mapOf("lkyrssyy", "dataaytzkdqimumaijcu", "rvrx", "dataedzhnyl", "jsqazecdomjrrolw",
- "datakpl")))
- .withPolicy(new ActivityPolicy().withTimeout("datacaqxstykusfqmgj")
- .withRetry("dataiqejvpdrcnoe")
- .withRetryIntervalInSeconds(730397817)
- .withSecureInput(true)
- .withSecureOutput(true)
+ .withUserProperties(Arrays.asList(new UserProperty().withName("jtgmfjzqvi").withValue("datadhixd")))
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("eblrnu")
+ .withParameters(mapOf("musudhjoshmmzotc", "datan", "difbeott", "dataffmik")))
+ .withPolicy(new ActivityPolicy().withTimeout("dataonejpjzqb")
+ .withRetry("datatv")
+ .withRetryIntervalInSeconds(148980075)
+ .withSecureInput(false)
+ .withSecureOutput(false)
.withAdditionalProperties(mapOf()))
.withNotebook(new SynapseNotebookReference().withType(NotebookReferenceType.NOTEBOOK_REFERENCE)
- .withReferenceName("datafroynfloam"))
+ .withReferenceName("datapfdhfp"))
.withSparkPool(
new BigDataPoolParametrizationReference().withType(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE)
- .withReferenceName("datafiivgdsnrknikp"))
- .withParameters(mapOf("hmfbzkfehrslvofn",
- new NotebookParameter().withValue("dataqnxyloyclrle").withType(NotebookParameterType.FLOAT), "ahsqo",
- new NotebookParameter().withValue("datawsuroddohng").withType(NotebookParameterType.FLOAT), "kdmnvaibh",
- new NotebookParameter().withValue("dataandslrndius").withType(NotebookParameterType.BOOL),
- "ssweznzfdext", new NotebookParameter().withValue("datajg").withType(NotebookParameterType.STRING)))
- .withExecutorSize("datarnhpxzjk")
- .withConf("datavzpcecisnhtds")
- .withDriverSize("datanigohafud")
- .withNumExecutors("datao")
- .withConfigurationType(ConfigurationType.DEFAULT)
+ .withReferenceName("datahggaziaps"))
+ .withParameters(mapOf("gmeiihabo",
+ new NotebookParameter().withValue("datamieheqmtet").withType(NotebookParameterType.STRING)))
+ .withExecutorSize("datargetnc")
+ .withConf("datajwjrpljkcqed")
+ .withDriverSize("dataeefzlwohobaaccg")
+ .withNumExecutors("datai")
+ .withConfigurationType(ConfigurationType.ARTIFACT)
.withTargetSparkConfiguration(new SparkConfigurationParametrizationReference()
.withType(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE)
- .withReferenceName("dataqgrcnf"))
- .withSparkConfig(mapOf("vfzl", "datagjvl", "j", "dataugxpugetw"));
+ .withReferenceName("dataoeiqhbrdcgmyjm"))
+ .withSparkConfig(mapOf("bzvink", "datakpbrr"));
model = BinaryData.fromObject(model).toObject(SynapseNotebookActivity.class);
- Assertions.assertEquals("ezcwfscxkrzuze", model.name());
- Assertions.assertEquals("vxmkzg", model.description());
+ Assertions.assertEquals("nfuvesmepqrkjyp", model.name());
+ Assertions.assertEquals("vnotbenfshf", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("sgebw", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("nyqsdsuewfgrijd", model.userProperties().get(0).name());
- Assertions.assertEquals("dddvfnqazvavsp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(730397817, model.policy().retryIntervalInSeconds());
- Assertions.assertEquals(true, model.policy().secureInput());
- Assertions.assertEquals(true, model.policy().secureOutput());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.onInactiveMarkAs());
+ Assertions.assertEquals("g", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("jtgmfjzqvi", model.userProperties().get(0).name());
+ Assertions.assertEquals("eblrnu", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(148980075, model.policy().retryIntervalInSeconds());
+ Assertions.assertEquals(false, model.policy().secureInput());
+ Assertions.assertEquals(false, model.policy().secureOutput());
Assertions.assertEquals(NotebookReferenceType.NOTEBOOK_REFERENCE, model.notebook().type());
Assertions.assertEquals(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE, model.sparkPool().type());
- Assertions.assertEquals(NotebookParameterType.FLOAT, model.parameters().get("hmfbzkfehrslvofn").type());
- Assertions.assertEquals(ConfigurationType.DEFAULT, model.configurationType());
+ Assertions.assertEquals(NotebookParameterType.STRING, model.parameters().get("gmeiihabo").type());
+ Assertions.assertEquals(ConfigurationType.ARTIFACT, model.configurationType());
Assertions.assertEquals(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE,
model.targetSparkConfiguration().type());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTypePropertiesTests.java
index 374f70bb3126..58249d7b02a8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookActivityTypePropertiesTests.java
@@ -23,11 +23,11 @@ public final class SynapseNotebookActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SynapseNotebookActivityTypeProperties model = BinaryData.fromString(
- "{\"notebook\":{\"type\":\"NotebookReference\",\"referenceName\":\"datahymdaeshjjqc\"},\"sparkPool\":{\"type\":\"BigDataPoolReference\",\"referenceName\":\"datan\"},\"parameters\":{\"whbkxzqryovlhm\":{\"value\":\"datae\",\"type\":\"int\"},\"aufmsyf\":{\"value\":\"dataobiagwuefmyiw\",\"type\":\"string\"},\"fyarl\":{\"value\":\"dataoreibce\",\"type\":\"int\"}},\"executorSize\":\"datalg\",\"conf\":\"datarqlbzcsffagun\",\"driverSize\":\"datateyh\",\"numExecutors\":\"datapkmkvkm\",\"configurationType\":\"Default\",\"targetSparkConfiguration\":{\"type\":\"SparkConfigurationReference\",\"referenceName\":\"datacw\"},\"sparkConfig\":{\"fdbahxcwjqtfs\":\"datavyosmxov\",\"uay\":\"datacakbezdvnez\",\"nkwhiyusjhmjlkkn\":\"dataejwqeypaoa\"}}")
+ "{\"notebook\":{\"type\":\"NotebookReference\",\"referenceName\":\"datacqpvrrmlk\"},\"sparkPool\":{\"type\":\"BigDataPoolReference\",\"referenceName\":\"dataqsdvxddsfylbo\"},\"parameters\":{\"nsbzkumxbcnkojy\":{\"value\":\"dataykrxaevburav\",\"type\":\"string\"},\"ia\":{\"value\":\"datahbtycfj\",\"type\":\"int\"}},\"executorSize\":\"datasukdoyb\",\"conf\":\"datazniekedxvw\",\"driverSize\":\"dataipxzzcxqd\",\"numExecutors\":\"datasuvekzqybpoxqwcu\",\"configurationType\":\"Default\",\"targetSparkConfiguration\":{\"type\":\"SparkConfigurationReference\",\"referenceName\":\"datazqazwyb\"},\"sparkConfig\":{\"cblmzaru\":\"datajvyrdownbwrnb\",\"abhpdkrjlwrqheh\":\"datasmpcajx\"}}")
.toObject(SynapseNotebookActivityTypeProperties.class);
Assertions.assertEquals(NotebookReferenceType.NOTEBOOK_REFERENCE, model.notebook().type());
Assertions.assertEquals(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE, model.sparkPool().type());
- Assertions.assertEquals(NotebookParameterType.INT, model.parameters().get("whbkxzqryovlhm").type());
+ Assertions.assertEquals(NotebookParameterType.STRING, model.parameters().get("nsbzkumxbcnkojy").type());
Assertions.assertEquals(ConfigurationType.DEFAULT, model.configurationType());
Assertions.assertEquals(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE,
model.targetSparkConfiguration().type());
@@ -37,28 +37,26 @@ public void testDeserialize() throws Exception {
public void testSerialize() throws Exception {
SynapseNotebookActivityTypeProperties model = new SynapseNotebookActivityTypeProperties()
.withNotebook(new SynapseNotebookReference().withType(NotebookReferenceType.NOTEBOOK_REFERENCE)
- .withReferenceName("datahymdaeshjjqc"))
+ .withReferenceName("datacqpvrrmlk"))
.withSparkPool(
new BigDataPoolParametrizationReference().withType(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE)
- .withReferenceName("datan"))
- .withParameters(mapOf("whbkxzqryovlhm",
- new NotebookParameter().withValue("datae").withType(NotebookParameterType.INT), "aufmsyf",
- new NotebookParameter().withValue("dataobiagwuefmyiw").withType(NotebookParameterType.STRING), "fyarl",
- new NotebookParameter().withValue("dataoreibce").withType(NotebookParameterType.INT)))
- .withExecutorSize("datalg")
- .withConf("datarqlbzcsffagun")
- .withDriverSize("datateyh")
- .withNumExecutors("datapkmkvkm")
+ .withReferenceName("dataqsdvxddsfylbo"))
+ .withParameters(mapOf("nsbzkumxbcnkojy",
+ new NotebookParameter().withValue("dataykrxaevburav").withType(NotebookParameterType.STRING), "ia",
+ new NotebookParameter().withValue("datahbtycfj").withType(NotebookParameterType.INT)))
+ .withExecutorSize("datasukdoyb")
+ .withConf("datazniekedxvw")
+ .withDriverSize("dataipxzzcxqd")
+ .withNumExecutors("datasuvekzqybpoxqwcu")
.withConfigurationType(ConfigurationType.DEFAULT)
.withTargetSparkConfiguration(new SparkConfigurationParametrizationReference()
.withType(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE)
- .withReferenceName("datacw"))
- .withSparkConfig(
- mapOf("fdbahxcwjqtfs", "datavyosmxov", "uay", "datacakbezdvnez", "nkwhiyusjhmjlkkn", "dataejwqeypaoa"));
+ .withReferenceName("datazqazwyb"))
+ .withSparkConfig(mapOf("cblmzaru", "datajvyrdownbwrnb", "abhpdkrjlwrqheh", "datasmpcajx"));
model = BinaryData.fromObject(model).toObject(SynapseNotebookActivityTypeProperties.class);
Assertions.assertEquals(NotebookReferenceType.NOTEBOOK_REFERENCE, model.notebook().type());
Assertions.assertEquals(BigDataPoolReferenceType.BIG_DATA_POOL_REFERENCE, model.sparkPool().type());
- Assertions.assertEquals(NotebookParameterType.INT, model.parameters().get("whbkxzqryovlhm").type());
+ Assertions.assertEquals(NotebookParameterType.STRING, model.parameters().get("nsbzkumxbcnkojy").type());
Assertions.assertEquals(ConfigurationType.DEFAULT, model.configurationType());
Assertions.assertEquals(SparkConfigurationReferenceType.SPARK_CONFIGURATION_REFERENCE,
model.targetSparkConfiguration().type());
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookReferenceTests.java
index 2c4e30902a42..a3a675d1b951 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseNotebookReferenceTests.java
@@ -13,7 +13,7 @@ public final class SynapseNotebookReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SynapseNotebookReference model
- = BinaryData.fromString("{\"type\":\"NotebookReference\",\"referenceName\":\"datajavmrnrhsvkjnl\"}")
+ = BinaryData.fromString("{\"type\":\"NotebookReference\",\"referenceName\":\"datazckgbpysgzgiv\"}")
.toObject(SynapseNotebookReference.class);
Assertions.assertEquals(NotebookReferenceType.NOTEBOOK_REFERENCE, model.type());
}
@@ -22,7 +22,7 @@ public void testDeserialize() throws Exception {
public void testSerialize() throws Exception {
SynapseNotebookReference model
= new SynapseNotebookReference().withType(NotebookReferenceType.NOTEBOOK_REFERENCE)
- .withReferenceName("datajavmrnrhsvkjnl");
+ .withReferenceName("datazckgbpysgzgiv");
model = BinaryData.fromObject(model).toObject(SynapseNotebookReference.class);
Assertions.assertEquals(NotebookReferenceType.NOTEBOOK_REFERENCE, model.type());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseSparkJobReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseSparkJobReferenceTests.java
index 4661300f636a..1d91d00ad81f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseSparkJobReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/SynapseSparkJobReferenceTests.java
@@ -13,7 +13,7 @@ public final class SynapseSparkJobReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
SynapseSparkJobReference model
- = BinaryData.fromString("{\"type\":\"SparkJobDefinitionReference\",\"referenceName\":\"dataiupdmbhaumpw\"}")
+ = BinaryData.fromString("{\"type\":\"SparkJobDefinitionReference\",\"referenceName\":\"datasbgj\"}")
.toObject(SynapseSparkJobReference.class);
Assertions.assertEquals(SparkJobReferenceType.SPARK_JOB_DEFINITION_REFERENCE, model.type());
}
@@ -22,7 +22,7 @@ public void testDeserialize() throws Exception {
public void testSerialize() throws Exception {
SynapseSparkJobReference model
= new SynapseSparkJobReference().withType(SparkJobReferenceType.SPARK_JOB_DEFINITION_REFERENCE)
- .withReferenceName("dataiupdmbhaumpw");
+ .withReferenceName("datasbgj");
model = BinaryData.fromObject(model).toObject(SynapseSparkJobReference.class);
Assertions.assertEquals(SparkJobReferenceType.SPARK_JOB_DEFINITION_REFERENCE, model.type());
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularSourceTests.java
index cc890ec22ebc..7757456aa2cc 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularSourceTests.java
@@ -11,18 +11,18 @@ public final class TabularSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TabularSource model = BinaryData.fromString(
- "{\"type\":\"TabularSource\",\"queryTimeout\":\"dataofts\",\"additionalColumns\":\"datafwusfbrnjvzl\",\"sourceRetryCount\":\"datavjemp\",\"sourceRetryWait\":\"databslwzntbieuq\",\"maxConcurrentConnections\":\"datakfi\",\"disableMetricsCollection\":\"datagbupuukpswwutduc\",\"\":{\"utmxt\":\"datandijzpvckh\",\"wljtwibwcdx\":\"datajssytd\"}}")
+ "{\"type\":\"TabularSource\",\"queryTimeout\":\"datamxdrgimsioff\",\"additionalColumns\":\"dataoonl\",\"sourceRetryCount\":\"datafundkhdmy\",\"sourceRetryWait\":\"datasbtqhhgn\",\"maxConcurrentConnections\":\"datacbjxgjudgbwr\",\"disableMetricsCollection\":\"dataiuzlfq\",\"\":{\"gsmlujunqwkjf\":\"datahlzljqcm\"}}")
.toObject(TabularSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TabularSource model = new TabularSource().withSourceRetryCount("datavjemp")
- .withSourceRetryWait("databslwzntbieuq")
- .withMaxConcurrentConnections("datakfi")
- .withDisableMetricsCollection("datagbupuukpswwutduc")
- .withQueryTimeout("dataofts")
- .withAdditionalColumns("datafwusfbrnjvzl");
+ TabularSource model = new TabularSource().withSourceRetryCount("datafundkhdmy")
+ .withSourceRetryWait("datasbtqhhgn")
+ .withMaxConcurrentConnections("datacbjxgjudgbwr")
+ .withDisableMetricsCollection("dataiuzlfq")
+ .withQueryTimeout("datamxdrgimsioff")
+ .withAdditionalColumns("dataoonl");
model = BinaryData.fromObject(model).toObject(TabularSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularTranslatorTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularTranslatorTests.java
index 3b6ac779aa72..98a06e41650c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularTranslatorTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TabularTranslatorTests.java
@@ -12,24 +12,24 @@ public final class TabularTranslatorTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TabularTranslator model = BinaryData.fromString(
- "{\"type\":\"TabularTranslator\",\"columnMappings\":\"datansdadyrhmpokfxc\",\"schemaMapping\":\"dataxmxga\",\"collectionReference\":\"dataracelnl\",\"mapComplexValuesToString\":\"datas\",\"mappings\":\"datauhjetxupxeains\",\"typeConversion\":\"datauugeae\",\"typeConversionSettings\":{\"allowDataTruncation\":\"datasxtsmzvaozfajalb\",\"treatBooleanAsNumber\":\"datawb\",\"dateTimeFormat\":\"datalvvazujc\",\"dateTimeOffsetFormat\":\"dataznwlxzmszxyfa\",\"timeSpanFormat\":\"datazvdqvdivzjy\",\"culture\":\"datajb\"},\"\":{\"qbut\":\"dataxjb\",\"vawe\":\"dataacnqudmyd\",\"wryrzoqyy\":\"datajqfbvbv\"}}")
+ "{\"type\":\"TabularTranslator\",\"columnMappings\":\"datapngyqlzozmbapj\",\"schemaMapping\":\"datazabl\",\"collectionReference\":\"datantjlzkymcgtbpb\",\"mapComplexValuesToString\":\"datagf\",\"mappings\":\"dataqwlvsefvkxxd\",\"typeConversion\":\"databnqmhrw\",\"typeConversionSettings\":{\"allowDataTruncation\":\"dataxwgrflqbugxudsmd\",\"treatBooleanAsNumber\":\"dataqrkstj\",\"dateTimeFormat\":\"datadasomxwsflylols\",\"dateTimeOffsetFormat\":\"dataiczwikglmcgyzz\",\"timeSpanFormat\":\"datadjx\",\"culture\":\"databjxkarxvguzvtw\"},\"\":{\"hd\":\"dataxoqnvi\",\"odnntoloezptngr\":\"dataolnxwdpp\",\"xacxcac\":\"datazvi\",\"u\":\"datacdkomr\"}}")
.toObject(TabularTranslator.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TabularTranslator model = new TabularTranslator().withColumnMappings("datansdadyrhmpokfxc")
- .withSchemaMapping("dataxmxga")
- .withCollectionReference("dataracelnl")
- .withMapComplexValuesToString("datas")
- .withMappings("datauhjetxupxeains")
- .withTypeConversion("datauugeae")
- .withTypeConversionSettings(new TypeConversionSettings().withAllowDataTruncation("datasxtsmzvaozfajalb")
- .withTreatBooleanAsNumber("datawb")
- .withDateTimeFormat("datalvvazujc")
- .withDateTimeOffsetFormat("dataznwlxzmszxyfa")
- .withTimeSpanFormat("datazvdqvdivzjy")
- .withCulture("datajb"));
+ TabularTranslator model = new TabularTranslator().withColumnMappings("datapngyqlzozmbapj")
+ .withSchemaMapping("datazabl")
+ .withCollectionReference("datantjlzkymcgtbpb")
+ .withMapComplexValuesToString("datagf")
+ .withMappings("dataqwlvsefvkxxd")
+ .withTypeConversion("databnqmhrw")
+ .withTypeConversionSettings(new TypeConversionSettings().withAllowDataTruncation("dataxwgrflqbugxudsmd")
+ .withTreatBooleanAsNumber("dataqrkstj")
+ .withDateTimeFormat("datadasomxwsflylols")
+ .withDateTimeOffsetFormat("dataiczwikglmcgyzz")
+ .withTimeSpanFormat("datadjx")
+ .withCulture("databjxkarxvguzvtw"));
model = BinaryData.fromObject(model).toObject(TabularTranslator.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarGZipReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarGZipReadSettingsTests.java
index 77cc80e3ba39..2a49749b9535 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarGZipReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarGZipReadSettingsTests.java
@@ -11,13 +11,14 @@ public final class TarGZipReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TarGZipReadSettings model = BinaryData.fromString(
- "{\"type\":\"TarGZipReadSettings\",\"preserveCompressionFileNameAsFolder\":\"datapwmveyrc\",\"\":{\"sz\":\"datadmoufjuqowuicvjy\",\"lwkcgu\":\"dataleuqxhmr\",\"lxxzn\":\"datavpvta\"}}")
+ "{\"type\":\"TarGZipReadSettings\",\"preserveCompressionFileNameAsFolder\":\"databjrsdiufqxrl\",\"\":{\"idnewrvjgwnmxc\":\"dataosuzegmcmlzmfe\",\"orzozf\":\"datagowdavpqyhax\"}}")
.toObject(TarGZipReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TarGZipReadSettings model = new TarGZipReadSettings().withPreserveCompressionFileNameAsFolder("datapwmveyrc");
+ TarGZipReadSettings model
+ = new TarGZipReadSettings().withPreserveCompressionFileNameAsFolder("databjrsdiufqxrl");
model = BinaryData.fromObject(model).toObject(TarGZipReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarReadSettingsTests.java
index 04c285565c74..5e03467e75aa 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TarReadSettingsTests.java
@@ -11,13 +11,13 @@ public final class TarReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TarReadSettings model = BinaryData.fromString(
- "{\"type\":\"TarReadSettings\",\"preserveCompressionFileNameAsFolder\":\"datakrrp\",\"\":{\"djqomzrqkjqcsh\":\"dataoliaizsglavdttt\"}}")
+ "{\"type\":\"TarReadSettings\",\"preserveCompressionFileNameAsFolder\":\"dataqkyaghfvublszs\",\"\":{\"jpn\":\"datauxax\"}}")
.toObject(TarReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TarReadSettings model = new TarReadSettings().withPreserveCompressionFileNameAsFolder("datakrrp");
+ TarReadSettings model = new TarReadSettings().withPreserveCompressionFileNameAsFolder("dataqkyaghfvublszs");
model = BinaryData.fromObject(model).toObject(TarReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataPartitionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataPartitionSettingsTests.java
index f1a04ceca951..be9f0bd73fe4 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataPartitionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataPartitionSettingsTests.java
@@ -11,15 +11,15 @@ public final class TeradataPartitionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TeradataPartitionSettings model = BinaryData.fromString(
- "{\"partitionColumnName\":\"datauqkdieu\",\"partitionUpperBound\":\"datawsak\",\"partitionLowerBound\":\"datamizcfkclf\"}")
+ "{\"partitionColumnName\":\"datacntdwijx\",\"partitionUpperBound\":\"dataltowdwiffagfe\",\"partitionLowerBound\":\"datambpgcbltthsuzx\"}")
.toObject(TeradataPartitionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TeradataPartitionSettings model = new TeradataPartitionSettings().withPartitionColumnName("datauqkdieu")
- .withPartitionUpperBound("datawsak")
- .withPartitionLowerBound("datamizcfkclf");
+ TeradataPartitionSettings model = new TeradataPartitionSettings().withPartitionColumnName("datacntdwijx")
+ .withPartitionUpperBound("dataltowdwiffagfe")
+ .withPartitionLowerBound("datambpgcbltthsuzx");
model = BinaryData.fromObject(model).toObject(TeradataPartitionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataSourceTests.java
index 82b238e8a88e..d1b58eda061a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataSourceTests.java
@@ -12,23 +12,23 @@ public final class TeradataSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TeradataSource model = BinaryData.fromString(
- "{\"type\":\"TeradataSource\",\"query\":\"datarfpnbyxy\",\"partitionOption\":\"databvidps\",\"partitionSettings\":{\"partitionColumnName\":\"datassxh\",\"partitionUpperBound\":\"datagliufdctgsd\",\"partitionLowerBound\":\"dataxkddxoatlprs\"},\"queryTimeout\":\"dataen\",\"additionalColumns\":\"datayyvvlgsa\",\"sourceRetryCount\":\"datavmnjtf\",\"sourceRetryWait\":\"datagx\",\"maxConcurrentConnections\":\"datarctbxpuis\",\"disableMetricsCollection\":\"dataamgnpeosusi\",\"\":{\"mwali\":\"dataofljab\"}}")
+ "{\"type\":\"TeradataSource\",\"query\":\"datahndcpiwcgcw\",\"partitionOption\":\"datahlpqxjxhdwjfx\",\"partitionSettings\":{\"partitionColumnName\":\"dataclka\",\"partitionUpperBound\":\"datauomga\",\"partitionLowerBound\":\"datac\"},\"queryTimeout\":\"datajjfmzv\",\"additionalColumns\":\"databflyzc\",\"sourceRetryCount\":\"datamlybsy\",\"sourceRetryWait\":\"dataon\",\"maxConcurrentConnections\":\"datavbfpu\",\"disableMetricsCollection\":\"dataobtdhum\",\"\":{\"jefclih\":\"datawckapoetdfzj\",\"lqzopvhwmtdbfrj\":\"datanawipdqozv\",\"uv\":\"dataq\",\"feagordbs\":\"dataps\"}}")
.toObject(TeradataSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TeradataSource model = new TeradataSource().withSourceRetryCount("datavmnjtf")
- .withSourceRetryWait("datagx")
- .withMaxConcurrentConnections("datarctbxpuis")
- .withDisableMetricsCollection("dataamgnpeosusi")
- .withQueryTimeout("dataen")
- .withAdditionalColumns("datayyvvlgsa")
- .withQuery("datarfpnbyxy")
- .withPartitionOption("databvidps")
- .withPartitionSettings(new TeradataPartitionSettings().withPartitionColumnName("datassxh")
- .withPartitionUpperBound("datagliufdctgsd")
- .withPartitionLowerBound("dataxkddxoatlprs"));
+ TeradataSource model = new TeradataSource().withSourceRetryCount("datamlybsy")
+ .withSourceRetryWait("dataon")
+ .withMaxConcurrentConnections("datavbfpu")
+ .withDisableMetricsCollection("dataobtdhum")
+ .withQueryTimeout("datajjfmzv")
+ .withAdditionalColumns("databflyzc")
+ .withQuery("datahndcpiwcgcw")
+ .withPartitionOption("datahlpqxjxhdwjfx")
+ .withPartitionSettings(new TeradataPartitionSettings().withPartitionColumnName("dataclka")
+ .withPartitionUpperBound("datauomga")
+ .withPartitionLowerBound("datac"));
model = BinaryData.fromObject(model).toObject(TeradataSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTests.java
index 541f7c01e146..2c8d19a44dfd 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTests.java
@@ -19,35 +19,32 @@ public final class TeradataTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TeradataTableDataset model = BinaryData.fromString(
- "{\"type\":\"TeradataTable\",\"typeProperties\":{\"database\":\"datalnzffewvqky\",\"table\":\"datacgeipqxxsdyaf\"},\"description\":\"ydsmmabh\",\"structure\":\"datalejqzhpvhxp\",\"schema\":\"datadjze\",\"linkedServiceName\":{\"referenceName\":\"llgfy\",\"parameters\":{\"mwdz\":\"dataqscjpvqerqxk\",\"x\":\"datazlhcu\",\"kfrwxohlydsnjz\":\"dataqpwwvmbjecfwlbgh\",\"hi\":\"datachiypbfhm\"}},\"parameters\":{\"srjzgkbrau\":{\"type\":\"SecureString\",\"defaultValue\":\"dataewb\"},\"rukbuudrizwkw\":{\"type\":\"Int\",\"defaultValue\":\"dataufqnnqbjxgjwsr\"}},\"annotations\":[\"datalaacedikqe\"],\"folder\":{\"name\":\"yb\"},\"\":{\"rommkiqhypwt\":\"datavgb\"}}")
+ "{\"type\":\"TeradataTable\",\"typeProperties\":{\"database\":\"datairgcjfai\",\"table\":\"datalpj\"},\"description\":\"krxifqn\",\"structure\":\"dataorxsqtzngxbsale\",\"schema\":\"datauxcmmhipbvskc\",\"linkedServiceName\":{\"referenceName\":\"tlynkwfsaangfg\",\"parameters\":{\"idyli\":\"datavm\"}},\"parameters\":{\"eonmzrjjaojp\":{\"type\":\"Bool\",\"defaultValue\":\"datanacgdnx\"}},\"annotations\":[\"datad\",\"datazigecwsad\"],\"folder\":{\"name\":\"udd\"},\"\":{\"vyigdeipnf\":\"dataqdmohheuyuunxmy\"}}")
.toObject(TeradataTableDataset.class);
- Assertions.assertEquals("ydsmmabh", model.description());
- Assertions.assertEquals("llgfy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("srjzgkbrau").type());
- Assertions.assertEquals("yb", model.folder().name());
+ Assertions.assertEquals("krxifqn", model.description());
+ Assertions.assertEquals("tlynkwfsaangfg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("eonmzrjjaojp").type());
+ Assertions.assertEquals("udd", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TeradataTableDataset model = new TeradataTableDataset().withDescription("ydsmmabh")
- .withStructure("datalejqzhpvhxp")
- .withSchema("datadjze")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("llgfy")
- .withParameters(mapOf("mwdz", "dataqscjpvqerqxk", "x", "datazlhcu", "kfrwxohlydsnjz",
- "dataqpwwvmbjecfwlbgh", "hi", "datachiypbfhm")))
- .withParameters(mapOf("srjzgkbrau",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("dataewb"),
- "rukbuudrizwkw",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("dataufqnnqbjxgjwsr")))
- .withAnnotations(Arrays.asList("datalaacedikqe"))
- .withFolder(new DatasetFolder().withName("yb"))
- .withDatabase("datalnzffewvqky")
- .withTable("datacgeipqxxsdyaf");
+ TeradataTableDataset model = new TeradataTableDataset().withDescription("krxifqn")
+ .withStructure("dataorxsqtzngxbsale")
+ .withSchema("datauxcmmhipbvskc")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tlynkwfsaangfg")
+ .withParameters(mapOf("idyli", "datavm")))
+ .withParameters(mapOf("eonmzrjjaojp",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datanacgdnx")))
+ .withAnnotations(Arrays.asList("datad", "datazigecwsad"))
+ .withFolder(new DatasetFolder().withName("udd"))
+ .withDatabase("datairgcjfai")
+ .withTable("datalpj");
model = BinaryData.fromObject(model).toObject(TeradataTableDataset.class);
- Assertions.assertEquals("ydsmmabh", model.description());
- Assertions.assertEquals("llgfy", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("srjzgkbrau").type());
- Assertions.assertEquals("yb", model.folder().name());
+ Assertions.assertEquals("krxifqn", model.description());
+ Assertions.assertEquals("tlynkwfsaangfg", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("eonmzrjjaojp").type());
+ Assertions.assertEquals("udd", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTypePropertiesTests.java
index a8ba96b55770..6414225df9fe 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TeradataTableDatasetTypePropertiesTests.java
@@ -11,15 +11,14 @@ public final class TeradataTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TeradataTableDatasetTypeProperties model
- = BinaryData.fromString("{\"database\":\"datayjjyutomzqlna\",\"table\":\"datawiijcfqiywhxpsba\"}")
+ = BinaryData.fromString("{\"database\":\"dataejwli\",\"table\":\"datacndjzwhajo\"}")
.toObject(TeradataTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
TeradataTableDatasetTypeProperties model
- = new TeradataTableDatasetTypeProperties().withDatabase("datayjjyutomzqlna")
- .withTable("datawiijcfqiywhxpsba");
+ = new TeradataTableDatasetTypeProperties().withDatabase("dataejwli").withTable("datacndjzwhajo");
model = BinaryData.fromObject(model).toObject(TeradataTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerDependencyReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerDependencyReferenceTests.java
index b639a90ca0dd..2470370b3f12 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerDependencyReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerDependencyReferenceTests.java
@@ -14,18 +14,18 @@ public final class TriggerDependencyReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TriggerDependencyReference model = BinaryData.fromString(
- "{\"type\":\"TriggerDependencyReference\",\"referenceTrigger\":{\"type\":\"TriggerReference\",\"referenceName\":\"hfvbgj\"}}")
+ "{\"type\":\"TriggerDependencyReference\",\"referenceTrigger\":{\"type\":\"TriggerReference\",\"referenceName\":\"ilbsbhaq\"}}")
.toObject(TriggerDependencyReference.class);
Assertions.assertEquals(TriggerReferenceType.TRIGGER_REFERENCE, model.referenceTrigger().type());
- Assertions.assertEquals("hfvbgj", model.referenceTrigger().referenceName());
+ Assertions.assertEquals("ilbsbhaq", model.referenceTrigger().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
TriggerDependencyReference model = new TriggerDependencyReference().withReferenceTrigger(
- new TriggerReference().withType(TriggerReferenceType.TRIGGER_REFERENCE).withReferenceName("hfvbgj"));
+ new TriggerReference().withType(TriggerReferenceType.TRIGGER_REFERENCE).withReferenceName("ilbsbhaq"));
model = BinaryData.fromObject(model).toObject(TriggerDependencyReference.class);
Assertions.assertEquals(TriggerReferenceType.TRIGGER_REFERENCE, model.referenceTrigger().type());
- Assertions.assertEquals("hfvbgj", model.referenceTrigger().referenceName());
+ Assertions.assertEquals("ilbsbhaq", model.referenceTrigger().referenceName());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerReferenceTests.java
index 6bf2d2da56ed..9adf76a003d2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerReferenceTests.java
@@ -12,19 +12,18 @@
public final class TriggerReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- TriggerReference model
- = BinaryData.fromString("{\"type\":\"TriggerReference\",\"referenceName\":\"ddaqqklvyib\"}")
- .toObject(TriggerReference.class);
+ TriggerReference model = BinaryData.fromString("{\"type\":\"TriggerReference\",\"referenceName\":\"behrholj\"}")
+ .toObject(TriggerReference.class);
Assertions.assertEquals(TriggerReferenceType.TRIGGER_REFERENCE, model.type());
- Assertions.assertEquals("ddaqqklvyib", model.referenceName());
+ Assertions.assertEquals("behrholj", model.referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
TriggerReference model
- = new TriggerReference().withType(TriggerReferenceType.TRIGGER_REFERENCE).withReferenceName("ddaqqklvyib");
+ = new TriggerReference().withType(TriggerReferenceType.TRIGGER_REFERENCE).withReferenceName("behrholj");
model = BinaryData.fromObject(model).toObject(TriggerReference.class);
Assertions.assertEquals(TriggerReferenceType.TRIGGER_REFERENCE, model.type());
- Assertions.assertEquals("ddaqqklvyib", model.referenceName());
+ Assertions.assertEquals("behrholj", model.referenceName());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsCancelWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsCancelWithResponseMockTests.java
index 2931a9524b10..5d65e68bfaba 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsCancelWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsCancelWithResponseMockTests.java
@@ -28,7 +28,8 @@ public void testCancelWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
manager.triggerRuns()
- .cancelWithResponse("ijyzhmf", "ksqiqzmgxunld", "k", "qcnjiwzqn", com.azure.core.util.Context.NONE);
+ .cancelWithResponse("oexughztrmtimt", "auylqpzskng", "cbldpeforxa", "pmzkdisrgykrcj",
+ com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsRerunWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsRerunWithResponseMockTests.java
index b80a13e59685..b34eaa39685e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsRerunWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggerRunsRerunWithResponseMockTests.java
@@ -27,7 +27,8 @@ public void testRerunWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.triggerRuns().rerunWithResponse("l", "lpqfxyywsx", "xvjvwk", "aqqkq", com.azure.core.util.Context.NONE);
+ manager.triggerRuns()
+ .rerunWithResponse("elakvhgefv", "chyvbyagqip", "bq", "tcibbgijkwzjlki", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersCreateOrUpdateWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersCreateOrUpdateWithResponseMockTests.java
index 690e2f1e99de..34a8316e10eb 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersCreateOrUpdateWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersCreateOrUpdateWithResponseMockTests.java
@@ -25,7 +25,7 @@ public final class TriggersCreateOrUpdateWithResponseMockTests {
@Test
public void testCreateOrUpdateWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"Trigger\",\"description\":\"mm\",\"runtimeState\":\"Started\",\"annotations\":[\"datazfjlprljil\",\"datauavxidy\",\"datajmkfxzg\",\"datap\"],\"\":{\"fbreyvrlycikwqt\":\"datama\"}},\"name\":\"fryourlywxjvsqz\",\"type\":\"ysqy\",\"etag\":\"sqmikljc\",\"id\":\"ot\"}";
+ = "{\"properties\":{\"type\":\"Trigger\",\"description\":\"gpt\",\"runtimeState\":\"Started\",\"annotations\":[\"datacrtpz\"],\"\":{\"hbf\":\"datahwbzrbqpzgsr\",\"nvwaxmeyjimf\":\"dataffytw\",\"vu\":\"datamhc\",\"vtypvwfllrie\":\"datawzajdxmaimwuf\"}},\"name\":\"xbcgnphen\",\"type\":\"whk\",\"etag\":\"xohqvqpwzoqtvm\",\"id\":\"l\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -35,16 +35,16 @@ public void testCreateOrUpdateWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
TriggerResource response = manager.triggers()
- .define("sktzrdxxsbbdo")
- .withExistingFactory("usxyugidkgsjivdt", "tkqqdqxslbrttlw")
- .withProperties(new Trigger().withDescription("jnbcdnjexcyh")
- .withAnnotations(Arrays.asList("dataraubx", "databmqgimwivqph"))
- .withAdditionalProperties(mapOf("type", "Trigger", "runtimeState", "Stopped")))
- .withIfMatch("nyzytgkdw")
+ .define("kjaqlszlymyqpw")
+ .withExistingFactory("sbygm", "nxeyfkrcmxtbwolz")
+ .withProperties(new Trigger().withDescription("uwqmi")
+ .withAnnotations(Arrays.asList("datazmhcvrfqqmbuvt", "datawrmcym"))
+ .withAdditionalProperties(mapOf("type", "Trigger", "runtimeState", "Disabled")))
+ .withIfMatch("vlfffymrzoupip")
.create();
- Assertions.assertEquals("ot", response.id());
- Assertions.assertEquals("mm", response.properties().description());
+ Assertions.assertEquals("l", response.id());
+ Assertions.assertEquals("gpt", response.properties().description());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersDeleteWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersDeleteWithResponseMockTests.java
index 1acb6391459c..c5749af026de 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersDeleteWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersDeleteWithResponseMockTests.java
@@ -27,7 +27,7 @@ public void testDeleteWithResponse() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.triggers().deleteWithResponse("ktuge", "hqdoctgno", "qw", com.azure.core.util.Context.NONE);
+ manager.triggers().deleteWithResponse("g", "o", "bhfrg", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetEventSubscriptionStatusWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetEventSubscriptionStatusWithResponseMockTests.java
index 287ca1f69f62..fe95661fa0b2 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetEventSubscriptionStatusWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetEventSubscriptionStatusWithResponseMockTests.java
@@ -19,7 +19,7 @@
public final class TriggersGetEventSubscriptionStatusWithResponseMockTests {
@Test
public void testGetEventSubscriptionStatusWithResponse() throws Exception {
- String responseStr = "{\"triggerName\":\"dfmz\",\"status\":\"Disabled\"}";
+ String responseStr = "{\"triggerName\":\"tannmjpgzw\",\"status\":\"Provisioning\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -29,7 +29,7 @@ public void testGetEventSubscriptionStatusWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
TriggerSubscriptionOperationStatus response = manager.triggers()
- .getEventSubscriptionStatusWithResponse("jybtwgdlfg", "uojnikwzlowusa", "dmjiz",
+ .getEventSubscriptionStatusWithResponse("alhwbypvpds", "ycjuxabpuphg", "gmggkkjciz",
com.azure.core.util.Context.NONE)
.getValue();
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetWithResponseMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetWithResponseMockTests.java
index 60e956814745..ee4c001d9058 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetWithResponseMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersGetWithResponseMockTests.java
@@ -21,7 +21,7 @@ public final class TriggersGetWithResponseMockTests {
@Test
public void testGetWithResponse() throws Exception {
String responseStr
- = "{\"properties\":{\"type\":\"Trigger\",\"description\":\"jjrhvdxfs\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datailsrxc\",\"datayk\",\"datavksvflurrfnlhlfv\"],\"\":{\"cblvpwuqq\":\"datahy\",\"rcxamgvi\":\"datamfuuhmftshg\",\"y\":\"datazvvrfplkemvvlge\",\"plhwplyvqofpemc\":\"datash\"}},\"name\":\"xkifjvil\",\"type\":\"opw\",\"etag\":\"bewbxaufo\",\"id\":\"mdpgg\"}";
+ = "{\"properties\":{\"type\":\"Trigger\",\"description\":\"xdnckgdcszz\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datazle\",\"dataz\"],\"\":{\"seft\":\"dataeqmfzyhikhn\",\"ax\":\"datajzqfpfkdybe\",\"zcadoqijfll\":\"datathppjxtobeq\",\"wvg\":\"datamuzeolcgqjtvpalk\"}},\"name\":\"utdswjtuqw\",\"type\":\"pauiccjaea\",\"etag\":\"ebqhbbqodyv\",\"id\":\"coiaaagvaecwwd\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -31,10 +31,11 @@ public void testGetWithResponse() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
TriggerResource response = manager.triggers()
- .getWithResponse("zcvmr", "xebslausvbv", "ctiso", "fefyggbacmn", com.azure.core.util.Context.NONE)
+ .getWithResponse("klnrzoafxoyddush", "yjhhynlmxzdwpdw", "noukyz", "yeghmf",
+ com.azure.core.util.Context.NONE)
.getValue();
- Assertions.assertEquals("mdpgg", response.id());
- Assertions.assertEquals("jjrhvdxfs", response.properties().description());
+ Assertions.assertEquals("coiaaagvaecwwd", response.id());
+ Assertions.assertEquals("xdnckgdcszz", response.properties().description());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersListByFactoryMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersListByFactoryMockTests.java
index 2d6037af7f09..3fa48c35e2be 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersListByFactoryMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersListByFactoryMockTests.java
@@ -22,7 +22,7 @@ public final class TriggersListByFactoryMockTests {
@Test
public void testListByFactory() throws Exception {
String responseStr
- = "{\"value\":[{\"properties\":{\"type\":\"Trigger\",\"description\":\"ixxxgltqldlh\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datald\"],\"\":{\"nogyvpfyjlfnjmwb\":\"datacajhnnbp\",\"rpwkvz\":\"dataoqhy\",\"tfc\":\"databvdlhcyoykmp\",\"fea\":\"dataugitjnwajqzig\"}},\"name\":\"bkcqoyqmbup\",\"type\":\"bzhczyhtjqtzl\",\"etag\":\"qp\",\"id\":\"c\"}]}";
+ = "{\"value\":[{\"properties\":{\"type\":\"Trigger\",\"description\":\"klxnbbkbjnnzqzu\",\"runtimeState\":\"Started\",\"annotations\":[\"datavlacll\"],\"\":{\"ielyhow\":\"dataksguccotgqge\",\"bdcheydcts\":\"datanzwhypjpypalptjp\"}},\"name\":\"wqsszd\",\"type\":\"kgbzmcprtanagehb\",\"etag\":\"wkaatjssebydus\",\"id\":\"ilp\"}]}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -32,9 +32,9 @@ public void testListByFactory() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
PagedIterable response
- = manager.triggers().listByFactory("gaeeqgpvirozl", "ccpg", com.azure.core.util.Context.NONE);
+ = manager.triggers().listByFactory("rrixkobmrrnkdmn", "qhkju", com.azure.core.util.Context.NONE);
- Assertions.assertEquals("c", response.iterator().next().id());
- Assertions.assertEquals("ixxxgltqldlh", response.iterator().next().properties().description());
+ Assertions.assertEquals("ilp", response.iterator().next().id());
+ Assertions.assertEquals("klxnbbkbjnnzqzu", response.iterator().next().properties().description());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStartMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStartMockTests.java
index cc3581d30510..9cf541e5d438 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStartMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStartMockTests.java
@@ -27,7 +27,7 @@ public void testStart() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.triggers().start("qbc", "tlyyphtdwhmwxhv", "pumokmymspatpveb", com.azure.core.util.Context.NONE);
+ manager.triggers().start("vardbrdr", "jakezorhjh", "zqhbuuldztvumvx", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStopMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStopMockTests.java
index e4aee51637d3..c63026137c0f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStopMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersStopMockTests.java
@@ -27,7 +27,7 @@ public void testStop() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- manager.triggers().stop("esucrynsqxyow", "rbxejdwhrshlk", "wfpq", com.azure.core.util.Context.NONE);
+ manager.triggers().stop("rxgaiddgd", "khiqwuwxrcydmky", "ojc", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersSubscribeToEventsMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersSubscribeToEventsMockTests.java
index 1df246477026..746307565a62 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersSubscribeToEventsMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersSubscribeToEventsMockTests.java
@@ -19,7 +19,7 @@
public final class TriggersSubscribeToEventsMockTests {
@Test
public void testSubscribeToEvents() throws Exception {
- String responseStr = "{\"triggerName\":\"fjwtyvvkn\",\"status\":\"Unknown\"}";
+ String responseStr = "{\"triggerName\":\"qwqujpug\",\"status\":\"Provisioning\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -28,8 +28,8 @@ public void testSubscribeToEvents() throws Exception {
.authenticate(tokenRequestContext -> Mono.just(new AccessToken("this_is_a_token", OffsetDateTime.MAX)),
new AzureProfile("", "", AzureEnvironment.AZURE));
- TriggerSubscriptionOperationStatus response = manager.triggers()
- .subscribeToEvents("wtwjzzyi", "bbkly", "elvhxutctakkdjus", com.azure.core.util.Context.NONE);
+ TriggerSubscriptionOperationStatus response
+ = manager.triggers().subscribeToEvents("p", "yfhskrfevwcxzx", "gfxz", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersUnsubscribeFromEventsMockTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersUnsubscribeFromEventsMockTests.java
index 36876b3bf5e4..ef168cba9a7f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersUnsubscribeFromEventsMockTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TriggersUnsubscribeFromEventsMockTests.java
@@ -19,7 +19,7 @@
public final class TriggersUnsubscribeFromEventsMockTests {
@Test
public void testUnsubscribeFromEvents() throws Exception {
- String responseStr = "{\"triggerName\":\"wetfmp\",\"status\":\"Unknown\"}";
+ String responseStr = "{\"triggerName\":\"lyvzsk\",\"status\":\"Provisioning\"}";
HttpClient httpClient
= response -> Mono.just(new MockHttpResponse(response, 200, responseStr.getBytes(StandardCharsets.UTF_8)));
@@ -29,7 +29,7 @@ public void testUnsubscribeFromEvents() throws Exception {
new AzureProfile("", "", AzureEnvironment.AZURE));
TriggerSubscriptionOperationStatus response = manager.triggers()
- .unsubscribeFromEvents("cepxay", "wvpavutis", "wyclehagb", com.azure.core.util.Context.NONE);
+ .unsubscribeFromEvents("pzshgsidkz", "parpsrjsghuokjwv", "acwdukhzu", com.azure.core.util.Context.NONE);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerDependencyReferenceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerDependencyReferenceTests.java
index ddeeb273cdde..33c18f0c1c5c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerDependencyReferenceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerDependencyReferenceTests.java
@@ -14,26 +14,25 @@ public final class TumblingWindowTriggerDependencyReferenceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TumblingWindowTriggerDependencyReference model = BinaryData.fromString(
- "{\"type\":\"TumblingWindowTriggerDependencyReference\",\"offset\":\"xdls\",\"size\":\"glwnkkzt\",\"referenceTrigger\":{\"type\":\"TriggerReference\",\"referenceName\":\"qjrhjjqajyrhr\"}}")
+ "{\"type\":\"TumblingWindowTriggerDependencyReference\",\"offset\":\"cw\",\"size\":\"g\",\"referenceTrigger\":{\"type\":\"TriggerReference\",\"referenceName\":\"wwu\"}}")
.toObject(TumblingWindowTriggerDependencyReference.class);
Assertions.assertEquals(TriggerReferenceType.TRIGGER_REFERENCE, model.referenceTrigger().type());
- Assertions.assertEquals("qjrhjjqajyrhr", model.referenceTrigger().referenceName());
- Assertions.assertEquals("xdls", model.offset());
- Assertions.assertEquals("glwnkkzt", model.size());
+ Assertions.assertEquals("wwu", model.referenceTrigger().referenceName());
+ Assertions.assertEquals("cw", model.offset());
+ Assertions.assertEquals("g", model.size());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TumblingWindowTriggerDependencyReference model
- = new TumblingWindowTriggerDependencyReference()
- .withReferenceTrigger(new TriggerReference().withType(TriggerReferenceType.TRIGGER_REFERENCE)
- .withReferenceName("qjrhjjqajyrhr"))
- .withOffset("xdls")
- .withSize("glwnkkzt");
+ TumblingWindowTriggerDependencyReference model = new TumblingWindowTriggerDependencyReference()
+ .withReferenceTrigger(
+ new TriggerReference().withType(TriggerReferenceType.TRIGGER_REFERENCE).withReferenceName("wwu"))
+ .withOffset("cw")
+ .withSize("g");
model = BinaryData.fromObject(model).toObject(TumblingWindowTriggerDependencyReference.class);
Assertions.assertEquals(TriggerReferenceType.TRIGGER_REFERENCE, model.referenceTrigger().type());
- Assertions.assertEquals("qjrhjjqajyrhr", model.referenceTrigger().referenceName());
- Assertions.assertEquals("xdls", model.offset());
- Assertions.assertEquals("glwnkkzt", model.size());
+ Assertions.assertEquals("wwu", model.referenceTrigger().referenceName());
+ Assertions.assertEquals("cw", model.offset());
+ Assertions.assertEquals("g", model.size());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTests.java
index 84181dd51851..d01f7f224bce 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTests.java
@@ -21,45 +21,44 @@ public final class TumblingWindowTriggerTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TumblingWindowTrigger model = BinaryData.fromString(
- "{\"type\":\"TumblingWindowTrigger\",\"pipeline\":{\"pipelineReference\":{\"referenceName\":\"zwky\",\"name\":\"ndiybdoyyk\"},\"parameters\":{\"oxk\":\"dataiandktwi\",\"owjatyhkq\":\"dataynppqtxpj\",\"qzvawfpu\":\"datajcimoi\",\"kjcgupxnuv\":\"datagyhschamwofqntt\"}},\"typeProperties\":{\"frequency\":\"Minute\",\"interval\":1054429650,\"startTime\":\"2021-10-07T05:22:50Z\",\"endTime\":\"2021-05-15T18:23:14Z\",\"delay\":\"datamv\",\"maxConcurrency\":1121710310,\"retryPolicy\":{\"count\":\"dataiyo\",\"intervalInSeconds\":972348562},\"dependsOn\":[{\"type\":\"DependencyReference\"}]},\"description\":\"zokplolcalyvcxvc\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datantb\",\"datatdqsqb\"],\"\":{\"wd\":\"dataswzafqr\",\"d\":\"datafgfspzw\",\"kkscooqnvht\":\"datauxwvjcdjvlwczw\",\"m\":\"datafckrmrbaoidt\"}}")
+ "{\"type\":\"TumblingWindowTrigger\",\"pipeline\":{\"pipelineReference\":{\"referenceName\":\"jov\",\"name\":\"heijmwajvuwa\"},\"parameters\":{\"twow\":\"datamdlpbkfsl\",\"bobgwvhdbie\":\"datawrnkuwgrtvy\"}},\"typeProperties\":{\"frequency\":\"Hour\",\"interval\":181282605,\"startTime\":\"2021-02-19T11:56:14Z\",\"endTime\":\"2021-11-19T15:00:37Z\",\"delay\":\"datacaschhfmidkd\",\"maxConcurrency\":1051348296,\"retryPolicy\":{\"count\":\"datatessvmdoxxcvug\",\"intervalInSeconds\":102399606},\"dependsOn\":[{\"type\":\"DependencyReference\"},{\"type\":\"DependencyReference\"}]},\"description\":\"uukhssret\",\"runtimeState\":\"Disabled\",\"annotations\":[\"datazkc\"],\"\":{\"ogmcblwhzvnisinp\":\"dataqtdwk\",\"jajahngaczggfia\":\"datacwwpuka\",\"ozxotwra\":\"datamuptnhuybtmtokoh\"}}")
.toObject(TumblingWindowTrigger.class);
- Assertions.assertEquals("zokplolcalyvcxvc", model.description());
- Assertions.assertEquals("zwky", model.pipeline().pipelineReference().referenceName());
- Assertions.assertEquals("ndiybdoyyk", model.pipeline().pipelineReference().name());
- Assertions.assertEquals(TumblingWindowFrequency.MINUTE, model.frequency());
- Assertions.assertEquals(1054429650, model.interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-10-07T05:22:50Z"), model.startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-05-15T18:23:14Z"), model.endTime());
- Assertions.assertEquals(1121710310, model.maxConcurrency());
- Assertions.assertEquals(972348562, model.retryPolicy().intervalInSeconds());
+ Assertions.assertEquals("uukhssret", model.description());
+ Assertions.assertEquals("jov", model.pipeline().pipelineReference().referenceName());
+ Assertions.assertEquals("heijmwajvuwa", model.pipeline().pipelineReference().name());
+ Assertions.assertEquals(TumblingWindowFrequency.HOUR, model.frequency());
+ Assertions.assertEquals(181282605, model.interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-02-19T11:56:14Z"), model.startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-11-19T15:00:37Z"), model.endTime());
+ Assertions.assertEquals(1051348296, model.maxConcurrency());
+ Assertions.assertEquals(102399606, model.retryPolicy().intervalInSeconds());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TumblingWindowTrigger model = new TumblingWindowTrigger().withDescription("zokplolcalyvcxvc")
- .withAnnotations(Arrays.asList("datantb", "datatdqsqb"))
+ TumblingWindowTrigger model = new TumblingWindowTrigger().withDescription("uukhssret")
+ .withAnnotations(Arrays.asList("datazkc"))
.withPipeline(new TriggerPipelineReference()
- .withPipelineReference(new PipelineReference().withReferenceName("zwky").withName("ndiybdoyyk"))
- .withParameters(mapOf("oxk", "dataiandktwi", "owjatyhkq", "dataynppqtxpj", "qzvawfpu", "datajcimoi",
- "kjcgupxnuv", "datagyhschamwofqntt")))
- .withFrequency(TumblingWindowFrequency.MINUTE)
- .withInterval(1054429650)
- .withStartTime(OffsetDateTime.parse("2021-10-07T05:22:50Z"))
- .withEndTime(OffsetDateTime.parse("2021-05-15T18:23:14Z"))
- .withDelay("datamv")
- .withMaxConcurrency(1121710310)
- .withRetryPolicy(new RetryPolicy().withCount("dataiyo").withIntervalInSeconds(972348562))
- .withDependsOn(Arrays.asList(new DependencyReference()));
+ .withPipelineReference(new PipelineReference().withReferenceName("jov").withName("heijmwajvuwa"))
+ .withParameters(mapOf("twow", "datamdlpbkfsl", "bobgwvhdbie", "datawrnkuwgrtvy")))
+ .withFrequency(TumblingWindowFrequency.HOUR)
+ .withInterval(181282605)
+ .withStartTime(OffsetDateTime.parse("2021-02-19T11:56:14Z"))
+ .withEndTime(OffsetDateTime.parse("2021-11-19T15:00:37Z"))
+ .withDelay("datacaschhfmidkd")
+ .withMaxConcurrency(1051348296)
+ .withRetryPolicy(new RetryPolicy().withCount("datatessvmdoxxcvug").withIntervalInSeconds(102399606))
+ .withDependsOn(Arrays.asList(new DependencyReference(), new DependencyReference()));
model = BinaryData.fromObject(model).toObject(TumblingWindowTrigger.class);
- Assertions.assertEquals("zokplolcalyvcxvc", model.description());
- Assertions.assertEquals("zwky", model.pipeline().pipelineReference().referenceName());
- Assertions.assertEquals("ndiybdoyyk", model.pipeline().pipelineReference().name());
- Assertions.assertEquals(TumblingWindowFrequency.MINUTE, model.frequency());
- Assertions.assertEquals(1054429650, model.interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-10-07T05:22:50Z"), model.startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-05-15T18:23:14Z"), model.endTime());
- Assertions.assertEquals(1121710310, model.maxConcurrency());
- Assertions.assertEquals(972348562, model.retryPolicy().intervalInSeconds());
+ Assertions.assertEquals("uukhssret", model.description());
+ Assertions.assertEquals("jov", model.pipeline().pipelineReference().referenceName());
+ Assertions.assertEquals("heijmwajvuwa", model.pipeline().pipelineReference().name());
+ Assertions.assertEquals(TumblingWindowFrequency.HOUR, model.frequency());
+ Assertions.assertEquals(181282605, model.interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-02-19T11:56:14Z"), model.startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-11-19T15:00:37Z"), model.endTime());
+ Assertions.assertEquals(1051348296, model.maxConcurrency());
+ Assertions.assertEquals(102399606, model.retryPolicy().intervalInSeconds());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTypePropertiesTests.java
index a7b4196ef4a1..eb53dbb66b7d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TumblingWindowTriggerTypePropertiesTests.java
@@ -17,34 +17,33 @@ public final class TumblingWindowTriggerTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TumblingWindowTriggerTypeProperties model = BinaryData.fromString(
- "{\"frequency\":\"Hour\",\"interval\":970304872,\"startTime\":\"2021-08-17T12:53:33Z\",\"endTime\":\"2021-01-25T22:54:38Z\",\"delay\":\"dataghjsxpptsvppf\",\"maxConcurrency\":1539699858,\"retryPolicy\":{\"count\":\"dataxcijf\",\"intervalInSeconds\":370054397},\"dependsOn\":[{\"type\":\"DependencyReference\"},{\"type\":\"DependencyReference\"},{\"type\":\"DependencyReference\"},{\"type\":\"DependencyReference\"}]}")
+ "{\"frequency\":\"Month\",\"interval\":1778345999,\"startTime\":\"2020-12-31T14:40:01Z\",\"endTime\":\"2021-05-06T17:10:59Z\",\"delay\":\"datarellwfgyabglsarf\",\"maxConcurrency\":1381920773,\"retryPolicy\":{\"count\":\"datahcxudromhhsum\",\"intervalInSeconds\":367806},\"dependsOn\":[{\"type\":\"DependencyReference\"},{\"type\":\"DependencyReference\"}]}")
.toObject(TumblingWindowTriggerTypeProperties.class);
- Assertions.assertEquals(TumblingWindowFrequency.HOUR, model.frequency());
- Assertions.assertEquals(970304872, model.interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-08-17T12:53:33Z"), model.startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-01-25T22:54:38Z"), model.endTime());
- Assertions.assertEquals(1539699858, model.maxConcurrency());
- Assertions.assertEquals(370054397, model.retryPolicy().intervalInSeconds());
+ Assertions.assertEquals(TumblingWindowFrequency.MONTH, model.frequency());
+ Assertions.assertEquals(1778345999, model.interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2020-12-31T14:40:01Z"), model.startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-05-06T17:10:59Z"), model.endTime());
+ Assertions.assertEquals(1381920773, model.maxConcurrency());
+ Assertions.assertEquals(367806, model.retryPolicy().intervalInSeconds());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
TumblingWindowTriggerTypeProperties model
- = new TumblingWindowTriggerTypeProperties().withFrequency(TumblingWindowFrequency.HOUR)
- .withInterval(970304872)
- .withStartTime(OffsetDateTime.parse("2021-08-17T12:53:33Z"))
- .withEndTime(OffsetDateTime.parse("2021-01-25T22:54:38Z"))
- .withDelay("dataghjsxpptsvppf")
- .withMaxConcurrency(1539699858)
- .withRetryPolicy(new RetryPolicy().withCount("dataxcijf").withIntervalInSeconds(370054397))
- .withDependsOn(Arrays.asList(new DependencyReference(), new DependencyReference(),
- new DependencyReference(), new DependencyReference()));
+ = new TumblingWindowTriggerTypeProperties().withFrequency(TumblingWindowFrequency.MONTH)
+ .withInterval(1778345999)
+ .withStartTime(OffsetDateTime.parse("2020-12-31T14:40:01Z"))
+ .withEndTime(OffsetDateTime.parse("2021-05-06T17:10:59Z"))
+ .withDelay("datarellwfgyabglsarf")
+ .withMaxConcurrency(1381920773)
+ .withRetryPolicy(new RetryPolicy().withCount("datahcxudromhhsum").withIntervalInSeconds(367806))
+ .withDependsOn(Arrays.asList(new DependencyReference(), new DependencyReference()));
model = BinaryData.fromObject(model).toObject(TumblingWindowTriggerTypeProperties.class);
- Assertions.assertEquals(TumblingWindowFrequency.HOUR, model.frequency());
- Assertions.assertEquals(970304872, model.interval());
- Assertions.assertEquals(OffsetDateTime.parse("2021-08-17T12:53:33Z"), model.startTime());
- Assertions.assertEquals(OffsetDateTime.parse("2021-01-25T22:54:38Z"), model.endTime());
- Assertions.assertEquals(1539699858, model.maxConcurrency());
- Assertions.assertEquals(370054397, model.retryPolicy().intervalInSeconds());
+ Assertions.assertEquals(TumblingWindowFrequency.MONTH, model.frequency());
+ Assertions.assertEquals(1778345999, model.interval());
+ Assertions.assertEquals(OffsetDateTime.parse("2020-12-31T14:40:01Z"), model.startTime());
+ Assertions.assertEquals(OffsetDateTime.parse("2021-05-06T17:10:59Z"), model.endTime());
+ Assertions.assertEquals(1381920773, model.maxConcurrency());
+ Assertions.assertEquals(367806, model.retryPolicy().intervalInSeconds());
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TypeConversionSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TypeConversionSettingsTests.java
index cef1ae41f4d5..c6ed3df2d684 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TypeConversionSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/TypeConversionSettingsTests.java
@@ -11,18 +11,18 @@ public final class TypeConversionSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
TypeConversionSettings model = BinaryData.fromString(
- "{\"allowDataTruncation\":\"datadbgobhltm\",\"treatBooleanAsNumber\":\"datay\",\"dateTimeFormat\":\"dataqgrsytto\",\"dateTimeOffsetFormat\":\"datazbbxifacrhpuzcag\",\"timeSpanFormat\":\"datavpbwt\",\"culture\":\"datauiguo\"}")
+ "{\"allowDataTruncation\":\"datat\",\"treatBooleanAsNumber\":\"datapdqwywjnxdyskyr\",\"dateTimeFormat\":\"dataijxml\",\"dateTimeOffsetFormat\":\"dataymfxjsuwmbdt\",\"timeSpanFormat\":\"datatr\",\"culture\":\"dataybpr\"}")
.toObject(TypeConversionSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- TypeConversionSettings model = new TypeConversionSettings().withAllowDataTruncation("datadbgobhltm")
- .withTreatBooleanAsNumber("datay")
- .withDateTimeFormat("dataqgrsytto")
- .withDateTimeOffsetFormat("datazbbxifacrhpuzcag")
- .withTimeSpanFormat("datavpbwt")
- .withCulture("datauiguo");
+ TypeConversionSettings model = new TypeConversionSettings().withAllowDataTruncation("datat")
+ .withTreatBooleanAsNumber("datapdqwywjnxdyskyr")
+ .withDateTimeFormat("dataijxml")
+ .withDateTimeOffsetFormat("dataymfxjsuwmbdt")
+ .withTimeSpanFormat("datatr")
+ .withCulture("dataybpr");
model = BinaryData.fromObject(model).toObject(TypeConversionSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTests.java
index a7e3838baeef..0d652050a47e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTests.java
@@ -22,80 +22,123 @@ public final class UntilActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
UntilActivity model = BinaryData.fromString(
- "{\"type\":\"Until\",\"typeProperties\":{\"expression\":{\"value\":\"udfixhxl\"},\"timeout\":\"datazqhtgtadtootkgxx\",\"activities\":[{\"type\":\"Activity\",\"name\":\"enlqwxskltzzp\",\"description\":\"wgtmpytomftubh\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"yj\",\"dependencyConditions\":[\"Succeeded\"],\"\":{\"llihwpsrdaoixgqt\":\"datazdazxfz\",\"ix\":\"datasjnlekotqhd\"}},{\"activity\":\"nchyoimt\",\"dependencyConditions\":[\"Skipped\",\"Completed\",\"Succeeded\"],\"\":{\"bgclgby\":\"datawxeknhvccxuntghw\",\"kcqvhwzeukumlnfx\":\"datacbc\",\"iywzgvcmuiqir\":\"dataoqvgw\",\"zbnqmxirspj\":\"datasznxz\"}},{\"activity\":\"akrbew\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Succeeded\"],\"\":{\"xgmzyqftlafeco\":\"dataourwvgnsdluqu\",\"za\":\"datafnxtynus\"}}],\"userProperties\":[{\"name\":\"t\",\"value\":\"datanylkwb\"}],\"\":{\"egu\":\"datajfjuzwi\",\"zyyyl\":\"datazlmhpuqlsdwtejx\",\"qpccp\":\"dataxu\",\"hogjaubpl\":\"dataychob\"}}]},\"name\":\"zjglfrwymwujt\",\"description\":\"d\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"ljytyqbtij\",\"dependencyConditions\":[\"Completed\"],\"\":{\"rsrgbfaq\":\"datagclppwdfxhz\"}},{\"activity\":\"zakisipjgvmrb\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Completed\",\"Failed\"],\"\":{\"ffgconiydgnxs\":\"dataxuubwjopkldubqfb\",\"s\":\"datayytnmhlank\",\"khkiaybdivx\":\"datafvmfyxle\",\"zndlgq\":\"dataxwdfm\"}}],\"userProperties\":[{\"name\":\"jczcorct\",\"value\":\"datawtxaaf\"},{\"name\":\"vqhmsdodmrzsni\",\"value\":\"datakhbmwlfo\"},{\"name\":\"yt\",\"value\":\"datajphzxmcpsepkrdge\"}],\"\":{\"bp\":\"dataxkpxrfulqhhmnd\",\"jmel\":\"datadg\",\"gfaiyvmpfebsummy\":\"datakzmfmgboyliopbo\",\"ckuhgbrvh\":\"datarxnneqxsdupmr\"}}")
+ "{\"type\":\"Until\",\"typeProperties\":{\"expression\":{\"value\":\"fppwobhkqgb\"},\"timeout\":\"datazoixutiz\",\"activities\":[{\"type\":\"Activity\",\"name\":\"cnknkukem\",\"description\":\"svajbg\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"ankzyqi\",\"dependencyConditions\":[\"Completed\"],\"\":{\"oqrutbfkynwwmlzp\":\"datakehtrgybfumo\",\"n\":\"datarzazkaljuvm\",\"bfntgsju\":\"datalbzloae\"}},{\"activity\":\"gueggph\",\"dependencyConditions\":[\"Failed\"],\"\":{\"vafhriua\":\"datapgvw\",\"lafv\":\"dataqgkvkoynjucmyj\",\"qenbgymgjneoh\":\"datandkvbc\",\"bhg\":\"datakis\"}}],\"userProperties\":[{\"name\":\"jodskqyjsdxgefk\",\"value\":\"datarfih\"},{\"name\":\"tor\",\"value\":\"datachfuwfrqagp\"}],\"\":{\"dgpxdjkwyzqnl\":\"dataiun\",\"kaciq\":\"datazymiv\",\"gzrg\":\"dataagfkksywd\"}},{\"type\":\"Activity\",\"name\":\"flpuxyakofrsoes\",\"description\":\"ttkqcpclootceit\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"hidlscdoweorniy\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Succeeded\"],\"\":{\"sqcbxkww\":\"dataojbxkodcopirg\"}},{\"activity\":\"q\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Failed\"],\"\":{\"hyqj\":\"datafgjztzh\",\"rbirv\":\"dataga\"}},{\"activity\":\"xubbnb\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\",\"Skipped\"],\"\":{\"rzchkww\":\"dataauub\",\"lujwcyvpxbqujno\":\"databxjpytkakhvao\",\"gwzvdqpxicpozzhf\":\"datafxirjcc\"}},{\"activity\":\"uraqpcspsbrd\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Completed\"],\"\":{\"udqgf\":\"dataeasbvzufkzuzz\"}}],\"userProperties\":[{\"name\":\"mfqtnqaqltoxhf\",\"value\":\"datahawjovqtvbu\"},{\"name\":\"yqyfit\",\"value\":\"dataprbmmfqteox\"},{\"name\":\"ikdcjmbwrhpw\",\"value\":\"dataudegykzdspbjks\"}],\"\":{\"hjhivgera\":\"datar\"}},{\"type\":\"Activity\",\"name\":\"gxnafojt\",\"description\":\"qcxrvwduspxij\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"cgyvzpvz\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Succeeded\"],\"\":{\"poywymtwh\":\"datajucfsupkqpgfyjwx\",\"x\":\"datadgbg\",\"gia\":\"datazrzhkhmw\"}},{\"activity\":\"rftpgqxnyoakd\",\"dependencyConditions\":[\"Completed\",\"Succeeded\"],\"\":{\"fejtdboac\":\"datasujezgzsekbcedb\",\"ypykjorlrj\":\"datayacjypgbhf\",\"mibhkaqza\":\"datarzxa\"}},{\"activity\":\"jqslshceyhalbxr\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"rtcdavlri\":\"datafcoatsupaqzitho\",\"ezwkparj\":\"datamtke\",\"ykeawrumhzg\":\"dataxirsvjozexxzkci\"}}],\"userProperties\":[{\"name\":\"blags\",\"value\":\"datahdubqha\"},{\"name\":\"xlbo\",\"value\":\"datawnkhiwqiq\"}],\"\":{\"nntp\":\"databorm\",\"zsfdohytk\":\"datacffv\",\"wpeaivbzrms\":\"dataquhdyzuehqmtt\",\"fqameccuqkoat\":\"dataeddwjimrzavci\"}}]},\"name\":\"i\",\"description\":\"diecrbcv\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"abddjbz\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Completed\"],\"\":{\"x\":\"dataluqpzwlbc\",\"oihjnknfvpa\":\"databa\",\"anxuiiprfij\":\"dataraeeiboqc\",\"xs\":\"datailose\"}},{\"activity\":\"hfjzxeswzgrelg\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\"],\"\":{\"jo\":\"dataeolxbgg\",\"atglar\":\"datamtwehvuttn\"}}],\"userProperties\":[{\"name\":\"guarkrfa\",\"value\":\"dataffeahypjqagce\"},{\"name\":\"juclffpvdjfws\",\"value\":\"databplbtmwae\"},{\"name\":\"ybrhn\",\"value\":\"datacxh\"}],\"\":{\"cmwix\":\"dataabnpdnbtymhheu\"}}")
.toObject(UntilActivity.class);
- Assertions.assertEquals("zjglfrwymwujt", model.name());
- Assertions.assertEquals("d", model.description());
+ Assertions.assertEquals("i", model.name());
+ Assertions.assertEquals("diecrbcv", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("ljytyqbtij", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("abddjbz", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jczcorct", model.userProperties().get(0).name());
- Assertions.assertEquals("udfixhxl", model.expression().value());
- Assertions.assertEquals("enlqwxskltzzp", model.activities().get(0).name());
- Assertions.assertEquals("wgtmpytomftubh", model.activities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("yj", model.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED,
+ Assertions.assertEquals("guarkrfa", model.userProperties().get(0).name());
+ Assertions.assertEquals("fppwobhkqgb", model.expression().value());
+ Assertions.assertEquals("cnknkukem", model.activities().get(0).name());
+ Assertions.assertEquals("svajbg", model.activities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("ankzyqi", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("t", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("jodskqyjsdxgefk", model.activities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- UntilActivity model = new UntilActivity().withName("zjglfrwymwujt")
- .withDescription("d")
+ UntilActivity model = new UntilActivity().withName("i")
+ .withDescription("diecrbcv")
.withState(ActivityState.ACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ljytyqbtij")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("abddjbz")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED,
+ DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("zakisipjgvmrb")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED, DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("hfjzxeswzgrelg")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("jczcorct").withValue("datawtxaaf"),
- new UserProperty().withName("vqhmsdodmrzsni").withValue("datakhbmwlfo"),
- new UserProperty().withName("yt").withValue("datajphzxmcpsepkrdge")))
- .withExpression(new Expression().withValue("udfixhxl"))
- .withTimeout("datazqhtgtadtootkgxx")
- .withActivities(Arrays.asList(new Activity().withName("enlqwxskltzzp")
- .withDescription("wgtmpytomftubh")
- .withState(ActivityState.INACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("yj")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("nchyoimt")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
- DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("akrbew")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
- DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("t").withValue("datanylkwb")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ .withUserProperties(Arrays.asList(new UserProperty().withName("guarkrfa").withValue("dataffeahypjqagce"),
+ new UserProperty().withName("juclffpvdjfws").withValue("databplbtmwae"),
+ new UserProperty().withName("ybrhn").withValue("datacxh")))
+ .withExpression(new Expression().withValue("fppwobhkqgb"))
+ .withTimeout("datazoixutiz")
+ .withActivities(Arrays.asList(
+ new Activity().withName("cnknkukem")
+ .withDescription("svajbg")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("ankzyqi")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("gueggph")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("jodskqyjsdxgefk").withValue("datarfih"),
+ new UserProperty().withName("tor").withValue("datachfuwfrqagp")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("flpuxyakofrsoes")
+ .withDescription("ttkqcpclootceit")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("hidlscdoweorniy")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("q")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.FAILED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("xubbnb")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("uraqpcspsbrd")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("mfqtnqaqltoxhf").withValue("datahawjovqtvbu"),
+ new UserProperty().withName("yqyfit").withValue("dataprbmmfqteox"),
+ new UserProperty().withName("ikdcjmbwrhpw").withValue("dataudegykzdspbjks")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("gxnafojt")
+ .withDescription("qcxrvwduspxij")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("cgyvzpvz")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("rftpgqxnyoakd")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("jqslshceyhalbxr")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(new UserProperty().withName("blags").withValue("datahdubqha"),
+ new UserProperty().withName("xlbo").withValue("datawnkhiwqiq")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(UntilActivity.class);
- Assertions.assertEquals("zjglfrwymwujt", model.name());
- Assertions.assertEquals("d", model.description());
+ Assertions.assertEquals("i", model.name());
+ Assertions.assertEquals("diecrbcv", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
- Assertions.assertEquals("ljytyqbtij", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("abddjbz", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("jczcorct", model.userProperties().get(0).name());
- Assertions.assertEquals("udfixhxl", model.expression().value());
- Assertions.assertEquals("enlqwxskltzzp", model.activities().get(0).name());
- Assertions.assertEquals("wgtmpytomftubh", model.activities().get(0).description());
- Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("yj", model.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.SUCCEEDED,
+ Assertions.assertEquals("guarkrfa", model.userProperties().get(0).name());
+ Assertions.assertEquals("fppwobhkqgb", model.expression().value());
+ Assertions.assertEquals("cnknkukem", model.activities().get(0).name());
+ Assertions.assertEquals("svajbg", model.activities().get(0).description());
+ Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.activities().get(0).onInactiveMarkAs());
+ Assertions.assertEquals("ankzyqi", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.COMPLETED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("t", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("jodskqyjsdxgefk", model.activities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTypePropertiesTests.java
index 473ee8b21903..e4e85c224c2b 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/UntilActivityTypePropertiesTests.java
@@ -22,45 +22,99 @@ public final class UntilActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
UntilActivityTypeProperties model = BinaryData.fromString(
- "{\"expression\":{\"value\":\"skos\"},\"timeout\":\"datavclzutvqk\",\"activities\":[{\"type\":\"Activity\",\"name\":\"jm\",\"description\":\"fskqwjlohkaffyny\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"yijxkucxpqpax\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Failed\"],\"\":{\"ftiwbdm\":\"dataiufjnjgupjjppbal\",\"xgo\":\"datanuvawm\",\"yza\":\"datapzqrb\",\"qzmwxoogi\":\"datawrufiouafxp\"}}],\"userProperties\":[{\"name\":\"plzb\",\"value\":\"datavpuigtnjye\"},{\"name\":\"fvvi\",\"value\":\"dataxoitnqmiwlrijex\"}],\"\":{\"pyk\":\"datayve\",\"v\":\"datahrqusbtw\",\"vkxshkyluqxndmta\":\"datazgnxepapm\"}}]}")
+ "{\"expression\":{\"value\":\"rvrpujb\"},\"timeout\":\"dataviys\",\"activities\":[{\"type\":\"Activity\",\"name\":\"eihmv\",\"description\":\"pqfawwoxqj\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Succeeded\",\"dependsOn\":[{\"activity\":\"dwvvsnynvg\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Succeeded\",\"Failed\"],\"\":{\"ddzkkik\":\"datandekpzgdr\",\"vxyeqdinwqse\":\"dataot\",\"xmnsrejq\":\"datatqoxethrxlpgrvtz\"}}],\"userProperties\":[{\"name\":\"hesmhoviea\",\"value\":\"databkdaomx\"}],\"\":{\"xtxhxfsknmrce\":\"databen\",\"woflfniislohftm\":\"datadfbdxwywdyqpkw\"}},{\"type\":\"Activity\",\"name\":\"m\",\"description\":\"x\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"tsgopmatubt\",\"dependencyConditions\":[\"Failed\",\"Succeeded\",\"Succeeded\"],\"\":{\"nqopoelqfsfxth\":\"datar\",\"kqkvfthbnikoybrs\":\"datadzeu\",\"wqmtzhiku\":\"dataf\",\"oxmzvlofzdnvsr\":\"dataymis\"}},{\"activity\":\"l\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"xtxgrh\":\"dataafcxpvxrqegkw\",\"sb\":\"dataqbstodeu\"}},{\"activity\":\"dcoqm\",\"dependencyConditions\":[\"Failed\",\"Skipped\"],\"\":{\"rjrx\":\"datawkpvsij\"}},{\"activity\":\"cnfyknx\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Skipped\"],\"\":{\"ehkqmlldeksgejmp\":\"dataq\"}}],\"userProperties\":[{\"name\":\"jacnbep\",\"value\":\"dataqhpkaamoovrb\"},{\"name\":\"buoqbclhnlqxuxr\",\"value\":\"datagxvkzhqpkckwaaf\"},{\"name\":\"yscjawqhpijur\",\"value\":\"dataoihxibji\"},{\"name\":\"m\",\"value\":\"dataj\"}],\"\":{\"nbluxomzg\":\"datafurdjjzsijmsaa\",\"wuiopgyunf\":\"datajmnvukovxfkxnevc\"}},{\"type\":\"Activity\",\"name\":\"oco\",\"description\":\"gdkikpqmdiihm\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"o\",\"dependencyConditions\":[\"Skipped\",\"Skipped\",\"Succeeded\",\"Completed\"],\"\":{\"nuys\":\"datacx\",\"jevu\":\"datavxaymxldorqp\",\"vfvirgbguewtcq\":\"datayzglssogze\"}},{\"activity\":\"eoma\",\"dependencyConditions\":[\"Succeeded\",\"Completed\"],\"\":{\"byviykwrffxorwx\":\"datauwepojm\",\"oyqlcvtdyuozmtsj\":\"datacxpzje\"}},{\"activity\":\"npuquyatvsnkrxh\",\"dependencyConditions\":[\"Completed\",\"Failed\",\"Failed\",\"Skipped\"],\"\":{\"tjzid\":\"datagrzlrnuyhl\",\"nh\":\"datawzpauwhfh\"}},{\"activity\":\"lojca\",\"dependencyConditions\":[\"Completed\",\"Completed\"],\"\":{\"qlghrcctvlnnkvdr\":\"datawgsyi\",\"bqzxqid\":\"dataekxvlejh\",\"wrwjbanteeu\":\"datau\",\"rrqjioltdlppyk\":\"dataricaikfvjktfpoba\"}}],\"userProperties\":[{\"name\":\"srvghvfo\",\"value\":\"datarqmcgeqy\"}],\"\":{\"bviym\":\"datadnwtuc\"}}]}")
.toObject(UntilActivityTypeProperties.class);
- Assertions.assertEquals("skos", model.expression().value());
- Assertions.assertEquals("jm", model.activities().get(0).name());
- Assertions.assertEquals("fskqwjlohkaffyny", model.activities().get(0).description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
+ Assertions.assertEquals("rvrpujb", model.expression().value());
+ Assertions.assertEquals("eihmv", model.activities().get(0).name());
+ Assertions.assertEquals("pqfawwoxqj", model.activities().get(0).description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("yijxkucxpqpax", model.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED,
+ Assertions.assertEquals("dwvvsnynvg", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("plzb", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("hesmhoviea", model.activities().get(0).userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
UntilActivityTypeProperties model
- = new UntilActivityTypeProperties().withExpression(new Expression().withValue("skos"))
- .withTimeout("datavclzutvqk")
- .withActivities(Arrays.asList(new Activity().withName("jm")
- .withDescription("fskqwjlohkaffyny")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
- .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("yijxkucxpqpax")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
- DependencyCondition.COMPLETED, DependencyCondition.FAILED))
- .withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("plzb").withValue("datavpuigtnjye"),
- new UserProperty().withName("fvvi").withValue("dataxoitnqmiwlrijex")))
- .withAdditionalProperties(mapOf("type", "Activity"))));
+ = new UntilActivityTypeProperties().withExpression(new Expression().withValue("rvrpujb"))
+ .withTimeout("dataviys")
+ .withActivities(Arrays.asList(
+ new Activity().withName("eihmv")
+ .withDescription("pqfawwoxqj")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SUCCEEDED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("dwvvsnynvg")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("hesmhoviea").withValue("databkdaomx")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("m")
+ .withDescription("x")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(
+ new ActivityDependency().withActivity("tsgopmatubt")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("l")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("dcoqm")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.FAILED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("cnfyknx")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED,
+ DependencyCondition.COMPLETED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(Arrays.asList(
+ new UserProperty().withName("jacnbep").withValue("dataqhpkaamoovrb"),
+ new UserProperty().withName("buoqbclhnlqxuxr").withValue("datagxvkzhqpkckwaaf"),
+ new UserProperty()
+ .withName("yscjawqhpijur")
+ .withValue("dataoihxibji"),
+ new UserProperty().withName("m").withValue("dataj")))
+ .withAdditionalProperties(mapOf("type", "Activity")),
+ new Activity().withName("oco")
+ .withDescription("gdkikpqmdiihm")
+ .withState(ActivityState.ACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
+ .withDependsOn(Arrays.asList(new ActivityDependency().withActivity("o")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SKIPPED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("eoma")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("npuquyatvsnkrxh")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.FAILED,
+ DependencyCondition.FAILED, DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("lojca")
+ .withDependencyConditions(
+ Arrays.asList(DependencyCondition.COMPLETED, DependencyCondition.COMPLETED))
+ .withAdditionalProperties(mapOf())))
+ .withUserProperties(
+ Arrays.asList(new UserProperty().withName("srvghvfo").withValue("datarqmcgeqy")))
+ .withAdditionalProperties(mapOf("type", "Activity"))));
model = BinaryData.fromObject(model).toObject(UntilActivityTypeProperties.class);
- Assertions.assertEquals("skos", model.expression().value());
- Assertions.assertEquals("jm", model.activities().get(0).name());
- Assertions.assertEquals("fskqwjlohkaffyny", model.activities().get(0).description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.activities().get(0).state());
+ Assertions.assertEquals("rvrpujb", model.expression().value());
+ Assertions.assertEquals("eihmv", model.activities().get(0).name());
+ Assertions.assertEquals("pqfawwoxqj", model.activities().get(0).description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.activities().get(0).state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SUCCEEDED, model.activities().get(0).onInactiveMarkAs());
- Assertions.assertEquals("yijxkucxpqpax", model.activities().get(0).dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED,
+ Assertions.assertEquals("dwvvsnynvg", model.activities().get(0).dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED,
model.activities().get(0).dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("plzb", model.activities().get(0).userProperties().get(0).name());
+ Assertions.assertEquals("hesmhoviea", model.activities().get(0).userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTests.java
index a3851e40e690..2e8db358e29a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTests.java
@@ -21,51 +21,57 @@ public final class ValidationActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ValidationActivity model = BinaryData.fromString(
- "{\"type\":\"Validation\",\"typeProperties\":{\"timeout\":\"datasnbttefbbr\",\"sleep\":\"dataof\",\"minimumSize\":\"datashozjkwjwvdo\",\"childItems\":\"datacsgktfzstyacbek\",\"dataset\":{\"referenceName\":\"xev\",\"parameters\":{\"yhexlhlkpied\":\"datab\",\"zpynedtsibtdmgw\":\"datartvdc\",\"aawehxshamzfx\":\"datao\"}}},\"name\":\"cuvj\",\"description\":\"yvoswgkbzrmef\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ia\",\"dependencyConditions\":[\"Completed\"],\"\":{\"eykvgfhu\":\"dataghnqe\",\"rytkmfhbpcr\":\"datahotzygqdcaims\",\"sn\":\"dataynunrajtbumaid\"}},{\"activity\":\"vyutcvumvgttjvc\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"gx\":\"datanj\",\"kdqqombiao\":\"dataxkcen\"}}],\"userProperties\":[{\"name\":\"woixnuffraursqt\",\"value\":\"datahtqbh\"},{\"name\":\"dpnzqqti\",\"value\":\"datakreanakkg\"},{\"name\":\"fkigukfximwinway\",\"value\":\"datarlvhlferiqend\"},{\"name\":\"yc\",\"value\":\"datanghszgaubibizj\"}],\"\":{\"bpypwrvnv\":\"datafjogswfbqe\",\"bsx\":\"dataetaydhfgxyd\",\"t\":\"datahjsraumawfzyvxk\"}}")
+ "{\"type\":\"Validation\",\"typeProperties\":{\"timeout\":\"datanq\",\"sleep\":\"datanvdorsgcvgkn\",\"minimumSize\":\"datapcne\",\"childItems\":\"dataplcbq\",\"dataset\":{\"referenceName\":\"bbzfcjmhp\",\"parameters\":{\"xymby\":\"datajpdyztqpszbt\",\"xotizvw\":\"datatdnraxe\",\"vjiyluvebco\":\"datahadcotf\"}}},\"name\":\"bzs\",\"description\":\"eyokwaxehxsw\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"fttfqlcxymcmog\",\"dependencyConditions\":[\"Completed\",\"Succeeded\",\"Succeeded\",\"Succeeded\"],\"\":{\"wnicdgim\":\"datatsgsqoadsbace\",\"xzmxww\":\"databumpplbcarcyrftc\"}},{\"activity\":\"hdlrfyonnb\",\"dependencyConditions\":[\"Succeeded\",\"Completed\",\"Skipped\",\"Succeeded\"],\"\":{\"jcou\":\"datam\",\"zirkyxhqwoxm\":\"datazodolehchimzrc\"}},{\"activity\":\"obuanybfm\",\"dependencyConditions\":[\"Succeeded\",\"Failed\",\"Failed\",\"Succeeded\"],\"\":{\"kqufdmgmfyi\":\"datapfpsp\",\"rilhyfxmrq\":\"datarfkfgr\",\"eavawywofgccj\":\"dataicknygzdrdicwm\"}},{\"activity\":\"hjvvrrxclf\",\"dependencyConditions\":[\"Completed\"],\"\":{\"xxfkfthw\":\"dataqwyiuhhuftnuigx\",\"lstgsmeijgjbev\":\"dataossokafy\",\"wvdklgwoyw\":\"datasrcsyjx\"}}],\"userProperties\":[{\"name\":\"fmenbaj\",\"value\":\"dataeelbcsyaohizfysa\"}],\"\":{\"ddohxvcsoqxydcqp\":\"dataupft\",\"iwtkhcmoc\":\"dataywttdanu\",\"khmbks\":\"datagtmfug\",\"mhn\":\"datakkztexds\"}}")
.toObject(ValidationActivity.class);
- Assertions.assertEquals("cuvj", model.name());
- Assertions.assertEquals("yvoswgkbzrmef", model.description());
+ Assertions.assertEquals("bzs", model.name());
+ Assertions.assertEquals("eyokwaxehxsw", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ia", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("fttfqlcxymcmog", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("woixnuffraursqt", model.userProperties().get(0).name());
- Assertions.assertEquals("xev", model.dataset().referenceName());
+ Assertions.assertEquals("fmenbaj", model.userProperties().get(0).name());
+ Assertions.assertEquals("bbzfcjmhp", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ValidationActivity model = new ValidationActivity().withName("cuvj")
- .withDescription("yvoswgkbzrmef")
+ ValidationActivity model = new ValidationActivity().withName("bzs")
+ .withDescription("eyokwaxehxsw")
.withState(ActivityState.ACTIVE)
.withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ia")
- .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
+ new ActivityDependency().withActivity("fttfqlcxymcmog")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("hdlrfyonnb")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.COMPLETED, DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("vyutcvumvgttjvc")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ new ActivityDependency().withActivity("obuanybfm")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED,
+ DependencyCondition.FAILED, DependencyCondition.SUCCEEDED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("hjvvrrxclf")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(Arrays.asList(new UserProperty().withName("woixnuffraursqt").withValue("datahtqbh"),
- new UserProperty().withName("dpnzqqti").withValue("datakreanakkg"),
- new UserProperty().withName("fkigukfximwinway").withValue("datarlvhlferiqend"),
- new UserProperty().withName("yc").withValue("datanghszgaubibizj")))
- .withTimeout("datasnbttefbbr")
- .withSleep("dataof")
- .withMinimumSize("datashozjkwjwvdo")
- .withChildItems("datacsgktfzstyacbek")
- .withDataset(new DatasetReference().withReferenceName("xev")
+ .withUserProperties(Arrays.asList(new UserProperty().withName("fmenbaj").withValue("dataeelbcsyaohizfysa")))
+ .withTimeout("datanq")
+ .withSleep("datanvdorsgcvgkn")
+ .withMinimumSize("datapcne")
+ .withChildItems("dataplcbq")
+ .withDataset(new DatasetReference().withReferenceName("bbzfcjmhp")
.withParameters(
- mapOf("yhexlhlkpied", "datab", "zpynedtsibtdmgw", "datartvdc", "aawehxshamzfx", "datao")));
+ mapOf("xymby", "datajpdyztqpszbt", "xotizvw", "datatdnraxe", "vjiyluvebco", "datahadcotf")));
model = BinaryData.fromObject(model).toObject(ValidationActivity.class);
- Assertions.assertEquals("cuvj", model.name());
- Assertions.assertEquals("yvoswgkbzrmef", model.description());
+ Assertions.assertEquals("bzs", model.name());
+ Assertions.assertEquals("eyokwaxehxsw", model.description());
Assertions.assertEquals(ActivityState.ACTIVE, model.state());
Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ia", model.dependsOn().get(0).activity());
+ Assertions.assertEquals("fttfqlcxymcmog", model.dependsOn().get(0).activity());
Assertions.assertEquals(DependencyCondition.COMPLETED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("woixnuffraursqt", model.userProperties().get(0).name());
- Assertions.assertEquals("xev", model.dataset().referenceName());
+ Assertions.assertEquals("fmenbaj", model.userProperties().get(0).name());
+ Assertions.assertEquals("bbzfcjmhp", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTypePropertiesTests.java
index ada27ab8d734..4127c3935eba 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ValidationActivityTypePropertiesTests.java
@@ -15,22 +15,22 @@ public final class ValidationActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ValidationActivityTypeProperties model = BinaryData.fromString(
- "{\"timeout\":\"dataf\",\"sleep\":\"datarhoujkcpyerf\",\"minimumSize\":\"datagtrijbolksehty\",\"childItems\":\"datagsurfnktxht\",\"dataset\":{\"referenceName\":\"rzdqqo\",\"parameters\":{\"dkqwffcv\":\"dataaltccttjibognhu\",\"bhkqgbijzo\":\"datahknvnfppw\",\"lscnknkukempa\":\"dataxuti\",\"kstkankzyqizxujl\":\"datavajbgpu\"}}}")
+ "{\"timeout\":\"datardveccmqenfgba\",\"sleep\":\"datauythdenvkolfi\",\"minimumSize\":\"dataoxohjyvpfisyyd\",\"childItems\":\"datamc\",\"dataset\":{\"referenceName\":\"wvcfayllxvhqvmi\",\"parameters\":{\"ogpetsmyfgtedfm\":\"dataxeaq\",\"odky\":\"dataorut\"}}}")
.toObject(ValidationActivityTypeProperties.class);
- Assertions.assertEquals("rzdqqo", model.dataset().referenceName());
+ Assertions.assertEquals("wvcfayllxvhqvmi", model.dataset().referenceName());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ValidationActivityTypeProperties model = new ValidationActivityTypeProperties().withTimeout("dataf")
- .withSleep("datarhoujkcpyerf")
- .withMinimumSize("datagtrijbolksehty")
- .withChildItems("datagsurfnktxht")
- .withDataset(new DatasetReference().withReferenceName("rzdqqo")
- .withParameters(mapOf("dkqwffcv", "dataaltccttjibognhu", "bhkqgbijzo", "datahknvnfppw", "lscnknkukempa",
- "dataxuti", "kstkankzyqizxujl", "datavajbgpu")));
+ ValidationActivityTypeProperties model
+ = new ValidationActivityTypeProperties().withTimeout("datardveccmqenfgba")
+ .withSleep("datauythdenvkolfi")
+ .withMinimumSize("dataoxohjyvpfisyyd")
+ .withChildItems("datamc")
+ .withDataset(new DatasetReference().withReferenceName("wvcfayllxvhqvmi")
+ .withParameters(mapOf("ogpetsmyfgtedfm", "dataxeaq", "odky", "dataorut")));
model = BinaryData.fromObject(model).toObject(ValidationActivityTypeProperties.class);
- Assertions.assertEquals("rzdqqo", model.dataset().referenceName());
+ Assertions.assertEquals("wvcfayllxvhqvmi", model.dataset().referenceName());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaDatasetTypePropertiesTests.java
index 857779727b88..c3ca40e60294 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaDatasetTypePropertiesTests.java
@@ -12,15 +12,15 @@ public final class VerticaDatasetTypePropertiesTests {
public void testDeserialize() throws Exception {
VerticaDatasetTypeProperties model = BinaryData
.fromString(
- "{\"tableName\":\"datawxhflgdun\",\"table\":\"dataypxsazbxsnx\",\"schema\":\"datasznfstmprvgra\"}")
+ "{\"tableName\":\"datafhlzzgaps\",\"table\":\"datawwblscrmzqu\",\"schema\":\"dataywkgouxnroy\"}")
.toObject(VerticaDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- VerticaDatasetTypeProperties model = new VerticaDatasetTypeProperties().withTableName("datawxhflgdun")
- .withTable("dataypxsazbxsnx")
- .withSchema("datasznfstmprvgra");
+ VerticaDatasetTypeProperties model = new VerticaDatasetTypeProperties().withTableName("datafhlzzgaps")
+ .withTable("datawwblscrmzqu")
+ .withSchema("dataywkgouxnroy");
model = BinaryData.fromObject(model).toObject(VerticaDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaSourceTests.java
index 902cf11bc7d9..99e7f2ad133a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaSourceTests.java
@@ -11,19 +11,19 @@ public final class VerticaSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
VerticaSource model = BinaryData.fromString(
- "{\"type\":\"VerticaSource\",\"query\":\"datapubsdinfauyt\",\"queryTimeout\":\"datavsdyqyjkmfo\",\"additionalColumns\":\"datamxedlcxm\",\"sourceRetryCount\":\"datatpbapojknvxantlp\",\"sourceRetryWait\":\"dataiipfgdnqpkvvrho\",\"maxConcurrentConnections\":\"datavqdvnruoduex\",\"disableMetricsCollection\":\"datakhkqlvocrddqxheg\",\"\":{\"zcklqrunqw\":\"datah\",\"pywgjgfbsfsvayg\":\"datarkkabyxxyfn\"}}")
+ "{\"type\":\"VerticaSource\",\"query\":\"datafyb\",\"queryTimeout\":\"datadzvuhw\",\"additionalColumns\":\"datanazjvyiiezdnez\",\"sourceRetryCount\":\"dataqzd\",\"sourceRetryWait\":\"datamyutzttroymi\",\"maxConcurrentConnections\":\"datakuz\",\"disableMetricsCollection\":\"datacegyztzhcfuwm\",\"\":{\"pxb\":\"datazumklroogflhho\"}}")
.toObject(VerticaSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- VerticaSource model = new VerticaSource().withSourceRetryCount("datatpbapojknvxantlp")
- .withSourceRetryWait("dataiipfgdnqpkvvrho")
- .withMaxConcurrentConnections("datavqdvnruoduex")
- .withDisableMetricsCollection("datakhkqlvocrddqxheg")
- .withQueryTimeout("datavsdyqyjkmfo")
- .withAdditionalColumns("datamxedlcxm")
- .withQuery("datapubsdinfauyt");
+ VerticaSource model = new VerticaSource().withSourceRetryCount("dataqzd")
+ .withSourceRetryWait("datamyutzttroymi")
+ .withMaxConcurrentConnections("datakuz")
+ .withDisableMetricsCollection("datacegyztzhcfuwm")
+ .withQueryTimeout("datadzvuhw")
+ .withAdditionalColumns("datanazjvyiiezdnez")
+ .withQuery("datafyb");
model = BinaryData.fromObject(model).toObject(VerticaSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaTableDatasetTests.java
index 24946bbf6e0d..2287d0716e3d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/VerticaTableDatasetTests.java
@@ -19,37 +19,34 @@ public final class VerticaTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
VerticaTableDataset model = BinaryData.fromString(
- "{\"type\":\"VerticaTable\",\"typeProperties\":{\"tableName\":\"dataxbofpr\",\"table\":\"dataiva\",\"schema\":\"datasbfzl\"},\"description\":\"jr\",\"structure\":\"datasfv\",\"schema\":\"datahqxtm\",\"linkedServiceName\":{\"referenceName\":\"lmfcleuovelvsp\",\"parameters\":{\"jtoudode\":\"datajtez\",\"sr\":\"datawmv\",\"emt\":\"dataciexu\"}},\"parameters\":{\"x\":{\"type\":\"Bool\",\"defaultValue\":\"dataymmcgskscb\"},\"wa\":{\"type\":\"SecureString\",\"defaultValue\":\"dataxicjojxolknsh\"},\"nchzz\":{\"type\":\"Int\",\"defaultValue\":\"databhmbglmnlbnat\"}},\"annotations\":[\"dataxortd\",\"datazvhbujk\",\"datahophqwo\"],\"folder\":{\"name\":\"ccqtwsrbf\"},\"\":{\"dzfbv\":\"dataii\",\"jtshlwvrsksdzmh\":\"dataxrvnhhmfsnqp\",\"pwfbwoetxiz\":\"datatsy\"}}")
+ "{\"type\":\"VerticaTable\",\"typeProperties\":{\"tableName\":\"datakuobclobnaqeizpl\",\"table\":\"datalyugpnn\",\"schema\":\"datajmkffeonmnvmu\"},\"description\":\"iqywlpxmliyt\",\"structure\":\"datagcrun\",\"schema\":\"datailxstekb\",\"linkedServiceName\":{\"referenceName\":\"rhyvs\",\"parameters\":{\"kltrvgioguoxc\":\"datariemorszffi\",\"gxgrggy\":\"datadqoxhdenmj\"}},\"parameters\":{\"xvvmrnjrdi\":{\"type\":\"Float\",\"defaultValue\":\"dataqinr\"},\"gcmpnc\":{\"type\":\"Bool\",\"defaultValue\":\"dataqswsychdcj\"}},\"annotations\":[\"datagbnoqnowvfxe\"],\"folder\":{\"name\":\"gwjekyqirvcpoln\"},\"\":{\"v\":\"datappdilb\"}}")
.toObject(VerticaTableDataset.class);
- Assertions.assertEquals("jr", model.description());
- Assertions.assertEquals("lmfcleuovelvsp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("x").type());
- Assertions.assertEquals("ccqtwsrbf", model.folder().name());
+ Assertions.assertEquals("iqywlpxmliyt", model.description());
+ Assertions.assertEquals("rhyvs", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("xvvmrnjrdi").type());
+ Assertions.assertEquals("gwjekyqirvcpoln", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- VerticaTableDataset model = new VerticaTableDataset().withDescription("jr")
- .withStructure("datasfv")
- .withSchema("datahqxtm")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("lmfcleuovelvsp")
- .withParameters(mapOf("jtoudode", "datajtez", "sr", "datawmv", "emt", "dataciexu")))
- .withParameters(mapOf("x",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataymmcgskscb"), "wa",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("dataxicjojxolknsh"),
- "nchzz",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("databhmbglmnlbnat")))
- .withAnnotations(Arrays.asList("dataxortd", "datazvhbujk", "datahophqwo"))
- .withFolder(new DatasetFolder().withName("ccqtwsrbf"))
- .withTableName("dataxbofpr")
- .withTable("dataiva")
- .withSchemaTypePropertiesSchema("datasbfzl");
+ VerticaTableDataset model = new VerticaTableDataset().withDescription("iqywlpxmliyt")
+ .withStructure("datagcrun")
+ .withSchema("datailxstekb")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rhyvs")
+ .withParameters(mapOf("kltrvgioguoxc", "datariemorszffi", "gxgrggy", "datadqoxhdenmj")))
+ .withParameters(mapOf("xvvmrnjrdi",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataqinr"), "gcmpnc",
+ new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("dataqswsychdcj")))
+ .withAnnotations(Arrays.asList("datagbnoqnowvfxe"))
+ .withFolder(new DatasetFolder().withName("gwjekyqirvcpoln"))
+ .withTableName("datakuobclobnaqeizpl")
+ .withTable("datalyugpnn")
+ .withSchemaTypePropertiesSchema("datajmkffeonmnvmu");
model = BinaryData.fromObject(model).toObject(VerticaTableDataset.class);
- Assertions.assertEquals("jr", model.description());
- Assertions.assertEquals("lmfcleuovelvsp", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.BOOL, model.parameters().get("x").type());
- Assertions.assertEquals("ccqtwsrbf", model.folder().name());
+ Assertions.assertEquals("iqywlpxmliyt", model.description());
+ Assertions.assertEquals("rhyvs", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("xvvmrnjrdi").type());
+ Assertions.assertEquals("gwjekyqirvcpoln", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTests.java
index 00585d26df89..8fa17cf9ea4c 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTests.java
@@ -20,47 +20,51 @@ public final class WaitActivityTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WaitActivity model = BinaryData.fromString(
- "{\"type\":\"Wait\",\"typeProperties\":{\"waitTimeInSeconds\":\"dataqqsbjbshwxyfskj\"},\"name\":\"ejkmltwftlh\",\"description\":\"tkxziowutcyj\",\"state\":\"Active\",\"onInactiveMarkAs\":\"Skipped\",\"dependsOn\":[{\"activity\":\"ohregqvus\",\"dependencyConditions\":[\"Failed\",\"Failed\",\"Failed\"],\"\":{\"wooorrn\":\"datavhmmirvmp\",\"cyltrxw\":\"datasthninzatdm\",\"b\":\"databw\"}},{\"activity\":\"lqgteoepdpx\",\"dependencyConditions\":[\"Succeeded\",\"Skipped\",\"Failed\"],\"\":{\"m\":\"dataqixomonqqqikeam\",\"g\":\"datalvoyd\",\"ccco\":\"datalcc\",\"vmzpoi\":\"datanljzqv\"}},{\"activity\":\"h\",\"dependencyConditions\":[\"Skipped\",\"Succeeded\"],\"\":{\"hydwkd\":\"datadkhvxtxu\",\"ydtllpwzayau\":\"dataycpzqjpyquy\",\"kfplhrenedsnu\":\"dataell\",\"skn\":\"datair\"}}],\"userProperties\":[{\"name\":\"vptoktrjwnqfdgc\",\"value\":\"datafngktmzooszv\"},{\"name\":\"ngkkf\",\"value\":\"dataebwqz\"}],\"\":{\"pidb\":\"datatyeqeasiadscjha\",\"lcowb\":\"dataqvi\",\"w\":\"datapvmndqmzcgqedono\",\"eaahnkntldddk\":\"datawhvqkeuiy\"}}")
+ "{\"type\":\"Wait\",\"typeProperties\":{\"waitTimeInSeconds\":\"dataevitvbz\"},\"name\":\"hexlhlkp\",\"description\":\"dcrtvdcbzpyn\",\"state\":\"Inactive\",\"onInactiveMarkAs\":\"Failed\",\"dependsOn\":[{\"activity\":\"dmgwxowaawe\",\"dependencyConditions\":[\"Succeeded\",\"Failed\"],\"\":{\"cuvj\":\"datazfx\",\"oswgkbzrmeftg\":\"datapy\"}},{\"activity\":\"fuuu\",\"dependencyConditions\":[\"Succeeded\",\"Succeeded\",\"Completed\"],\"\":{\"eykvgfhu\":\"dataghnqe\",\"rytkmfhbpcr\":\"datahotzygqdcaims\",\"sn\":\"dataynunrajtbumaid\"}},{\"activity\":\"vyutcvumvgttjvc\",\"dependencyConditions\":[\"Skipped\"],\"\":{\"gx\":\"datanj\",\"kdqqombiao\":\"dataxkcen\"}},{\"activity\":\"qwwoi\",\"dependencyConditions\":[\"Failed\",\"Completed\",\"Succeeded\",\"Succeeded\"],\"\":{\"pnzqqtipkreanak\":\"datarsqtjhtqbhr\",\"gukf\":\"datagqfk\"}}],\"userProperties\":[{\"name\":\"winwaymrlvhlf\",\"value\":\"datariqendtyccn\"},{\"name\":\"hszgaub\",\"value\":\"databizjbwufjogswf\"},{\"name\":\"qeebpyp\",\"value\":\"datarvnveetaydh\"},{\"name\":\"gxy\",\"value\":\"dataobsxshjsra\"}],\"\":{\"rhoujkcpyerf\":\"datawfzyvxkrtgofp\",\"ijbolksehtyx\":\"datangt\"}}")
.toObject(WaitActivity.class);
- Assertions.assertEquals("ejkmltwftlh", model.name());
- Assertions.assertEquals("tkxziowutcyj", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ohregqvus", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("vptoktrjwnqfdgc", model.userProperties().get(0).name());
+ Assertions.assertEquals("hexlhlkp", model.name());
+ Assertions.assertEquals("dcrtvdcbzpyn", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("dmgwxowaawe", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("winwaymrlvhlf", model.userProperties().get(0).name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WaitActivity model = new WaitActivity().withName("ejkmltwftlh")
- .withDescription("tkxziowutcyj")
- .withState(ActivityState.ACTIVE)
- .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.SKIPPED)
+ WaitActivity model = new WaitActivity().withName("hexlhlkp")
+ .withDescription("dcrtvdcbzpyn")
+ .withState(ActivityState.INACTIVE)
+ .withOnInactiveMarkAs(ActivityOnInactiveMarkAs.FAILED)
.withDependsOn(Arrays.asList(
- new ActivityDependency().withActivity("ohregqvus")
- .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.FAILED,
- DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("dmgwxowaawe")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.FAILED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("lqgteoepdpx")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED, DependencyCondition.SKIPPED,
- DependencyCondition.FAILED))
+ new ActivityDependency().withActivity("fuuu")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SUCCEEDED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.COMPLETED))
.withAdditionalProperties(mapOf()),
- new ActivityDependency().withActivity("h")
- .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED, DependencyCondition.SUCCEEDED))
+ new ActivityDependency().withActivity("vyutcvumvgttjvc")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.SKIPPED))
+ .withAdditionalProperties(mapOf()),
+ new ActivityDependency().withActivity("qwwoi")
+ .withDependencyConditions(Arrays.asList(DependencyCondition.FAILED, DependencyCondition.COMPLETED,
+ DependencyCondition.SUCCEEDED, DependencyCondition.SUCCEEDED))
.withAdditionalProperties(mapOf())))
- .withUserProperties(
- Arrays.asList(new UserProperty().withName("vptoktrjwnqfdgc").withValue("datafngktmzooszv"),
- new UserProperty().withName("ngkkf").withValue("dataebwqz")))
- .withWaitTimeInSeconds("dataqqsbjbshwxyfskj");
+ .withUserProperties(Arrays.asList(new UserProperty().withName("winwaymrlvhlf").withValue("datariqendtyccn"),
+ new UserProperty().withName("hszgaub").withValue("databizjbwufjogswf"),
+ new UserProperty().withName("qeebpyp").withValue("datarvnveetaydh"),
+ new UserProperty().withName("gxy").withValue("dataobsxshjsra")))
+ .withWaitTimeInSeconds("dataevitvbz");
model = BinaryData.fromObject(model).toObject(WaitActivity.class);
- Assertions.assertEquals("ejkmltwftlh", model.name());
- Assertions.assertEquals("tkxziowutcyj", model.description());
- Assertions.assertEquals(ActivityState.ACTIVE, model.state());
- Assertions.assertEquals(ActivityOnInactiveMarkAs.SKIPPED, model.onInactiveMarkAs());
- Assertions.assertEquals("ohregqvus", model.dependsOn().get(0).activity());
- Assertions.assertEquals(DependencyCondition.FAILED, model.dependsOn().get(0).dependencyConditions().get(0));
- Assertions.assertEquals("vptoktrjwnqfdgc", model.userProperties().get(0).name());
+ Assertions.assertEquals("hexlhlkp", model.name());
+ Assertions.assertEquals("dcrtvdcbzpyn", model.description());
+ Assertions.assertEquals(ActivityState.INACTIVE, model.state());
+ Assertions.assertEquals(ActivityOnInactiveMarkAs.FAILED, model.onInactiveMarkAs());
+ Assertions.assertEquals("dmgwxowaawe", model.dependsOn().get(0).activity());
+ Assertions.assertEquals(DependencyCondition.SUCCEEDED, model.dependsOn().get(0).dependencyConditions().get(0));
+ Assertions.assertEquals("winwaymrlvhlf", model.userProperties().get(0).name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTypePropertiesTests.java
index 91d1f007bdea..36ae16697959 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WaitActivityTypePropertiesTests.java
@@ -10,13 +10,13 @@
public final class WaitActivityTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
- WaitActivityTypeProperties model = BinaryData.fromString("{\"waitTimeInSeconds\":\"datapvusigw\"}")
+ WaitActivityTypeProperties model = BinaryData.fromString("{\"waitTimeInSeconds\":\"datagsurfnktxht\"}")
.toObject(WaitActivityTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WaitActivityTypeProperties model = new WaitActivityTypeProperties().withWaitTimeInSeconds("datapvusigw");
+ WaitActivityTypeProperties model = new WaitActivityTypeProperties().withWaitTimeInSeconds("datagsurfnktxht");
model = BinaryData.fromObject(model).toObject(WaitActivityTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSinkTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSinkTests.java
index 8dff2d53ef03..006cd96d257a 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSinkTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSinkTests.java
@@ -17,29 +17,29 @@ public final class WarehouseSinkTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WarehouseSink model = BinaryData.fromString(
- "{\"type\":\"WarehouseSink\",\"preCopyScript\":\"datangguucp\",\"allowCopyCommand\":\"datasxnujwffthbzii\",\"copyCommandSettings\":{\"defaultValues\":[{\"columnName\":\"dataccccr\",\"defaultValue\":\"dataabdevjrbgcdxqgst\"}],\"additionalOptions\":{\"uqwljmzp\":\"sbksvvyvoibv\",\"go\":\"ukrwvvhcgtctnqd\"}},\"tableOption\":\"datace\",\"writeBehavior\":\"datartputmtjsklkw\",\"writeBatchSize\":\"dataqqiqckmfxldqtman\",\"writeBatchTimeout\":\"dataj\",\"sinkRetryCount\":\"datamrfq\",\"sinkRetryWait\":\"datacdpwlezbfgullq\",\"maxConcurrentConnections\":\"dataijyxcmqcggksrorx\",\"disableMetricsCollection\":\"datafhar\",\"\":{\"ftraylxzdujpuhb\":\"datat\",\"smlbz\":\"dataogfwbkxdhavegys\",\"wyrioqwmhcpuj\":\"dataxpdatvndvwwejvq\"}}")
+ "{\"type\":\"WarehouseSink\",\"preCopyScript\":\"dataamshqvku\",\"allowCopyCommand\":\"datazvzqhvzjdsn\",\"copyCommandSettings\":{\"defaultValues\":[{\"columnName\":\"dataani\",\"defaultValue\":\"dataz\"}],\"additionalOptions\":{\"vwwvznp\":\"xaqugjalmzpfylq\"}},\"tableOption\":\"datacizropzgjleecffb\",\"writeBehavior\":\"datakvb\",\"writeBatchSize\":\"datastqwnpegoupdq\",\"writeBatchTimeout\":\"datalvd\",\"sinkRetryCount\":\"dataqcqlexobeekzy\",\"sinkRetryWait\":\"datapatwbbf\",\"maxConcurrentConnections\":\"dataflhnwohlc\",\"disableMetricsCollection\":\"datahfuydgdhitavga\",\"\":{\"zeebdefepwkhr\":\"datapzlcvibpd\",\"qvnlhsxea\":\"datazzwgbbozivfo\",\"km\":\"dataxsqquvvscb\",\"ibwuzvmorsyi\":\"datahdukprq\"}}")
.toObject(WarehouseSink.class);
- Assertions.assertEquals("sbksvvyvoibv", model.copyCommandSettings().additionalOptions().get("uqwljmzp"));
+ Assertions.assertEquals("xaqugjalmzpfylq", model.copyCommandSettings().additionalOptions().get("vwwvznp"));
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WarehouseSink model = new WarehouseSink().withWriteBatchSize("dataqqiqckmfxldqtman")
- .withWriteBatchTimeout("dataj")
- .withSinkRetryCount("datamrfq")
- .withSinkRetryWait("datacdpwlezbfgullq")
- .withMaxConcurrentConnections("dataijyxcmqcggksrorx")
- .withDisableMetricsCollection("datafhar")
- .withPreCopyScript("datangguucp")
- .withAllowCopyCommand("datasxnujwffthbzii")
+ WarehouseSink model = new WarehouseSink().withWriteBatchSize("datastqwnpegoupdq")
+ .withWriteBatchTimeout("datalvd")
+ .withSinkRetryCount("dataqcqlexobeekzy")
+ .withSinkRetryWait("datapatwbbf")
+ .withMaxConcurrentConnections("dataflhnwohlc")
+ .withDisableMetricsCollection("datahfuydgdhitavga")
+ .withPreCopyScript("dataamshqvku")
+ .withAllowCopyCommand("datazvzqhvzjdsn")
.withCopyCommandSettings(new DWCopyCommandSettings()
- .withDefaultValues(Arrays.asList(new DWCopyCommandDefaultValue().withColumnName("dataccccr")
- .withDefaultValue("dataabdevjrbgcdxqgst")))
- .withAdditionalOptions(mapOf("uqwljmzp", "sbksvvyvoibv", "go", "ukrwvvhcgtctnqd")))
- .withTableOption("datace")
- .withWriteBehavior("datartputmtjsklkw");
+ .withDefaultValues(
+ Arrays.asList(new DWCopyCommandDefaultValue().withColumnName("dataani").withDefaultValue("dataz")))
+ .withAdditionalOptions(mapOf("vwwvznp", "xaqugjalmzpfylq")))
+ .withTableOption("datacizropzgjleecffb")
+ .withWriteBehavior("datakvb");
model = BinaryData.fromObject(model).toObject(WarehouseSink.class);
- Assertions.assertEquals("sbksvvyvoibv", model.copyCommandSettings().additionalOptions().get("uqwljmzp"));
+ Assertions.assertEquals("xaqugjalmzpfylq", model.copyCommandSettings().additionalOptions().get("vwwvznp"));
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSourceTests.java
index a7eefe33537e..e1370f90726d 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseSourceTests.java
@@ -12,26 +12,26 @@ public final class WarehouseSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WarehouseSource model = BinaryData.fromString(
- "{\"type\":\"WarehouseSource\",\"sqlReaderQuery\":\"datavscndbklscokafaq\",\"sqlReaderStoredProcedureName\":\"datapvnvdzssssn\",\"storedProcedureParameters\":\"datahgid\",\"isolationLevel\":\"dataotx\",\"partitionOption\":\"databxzhad\",\"partitionSettings\":{\"partitionColumnName\":\"datannootc\",\"partitionUpperBound\":\"dataupaq\",\"partitionLowerBound\":\"dataodhnzkmjoyby\"},\"queryTimeout\":\"datawjrs\",\"additionalColumns\":\"datarykkhxawohs\",\"sourceRetryCount\":\"datawxphnlw\",\"sourceRetryWait\":\"datazv\",\"maxConcurrentConnections\":\"datax\",\"disableMetricsCollection\":\"dataeserlt\",\"\":{\"ksfxdmbxfyxweiq\":\"datajgjuopvkrms\",\"iucu\":\"datahfyvkxgoxsv\",\"ttdcfjalpsycvcks\":\"datawnojvcrgqmbnfvy\"}}")
+ "{\"type\":\"WarehouseSource\",\"sqlReaderQuery\":\"dataophtkyzsgayng\",\"sqlReaderStoredProcedureName\":\"datawvcnv\",\"storedProcedureParameters\":\"dataqxqhysu\",\"isolationLevel\":\"datadnslroqxrvycjdn\",\"partitionOption\":\"datamggy\",\"partitionSettings\":{\"partitionColumnName\":\"datamsacbamtoqseam\",\"partitionUpperBound\":\"dataxdigkggzmylq\",\"partitionLowerBound\":\"dataeosxdsxil\"},\"queryTimeout\":\"dataiottdawgkaohhtt\",\"additionalColumns\":\"datahypidzjjjfcyskpn\",\"sourceRetryCount\":\"dataxoic\",\"sourceRetryWait\":\"datasmfvltbocqhv\",\"maxConcurrentConnections\":\"datam\",\"disableMetricsCollection\":\"datapvgri\",\"\":{\"fmfkuvybem\":\"datagrlgkoqbzrclarr\"}}")
.toObject(WarehouseSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WarehouseSource model = new WarehouseSource().withSourceRetryCount("datawxphnlw")
- .withSourceRetryWait("datazv")
- .withMaxConcurrentConnections("datax")
- .withDisableMetricsCollection("dataeserlt")
- .withQueryTimeout("datawjrs")
- .withAdditionalColumns("datarykkhxawohs")
- .withSqlReaderQuery("datavscndbklscokafaq")
- .withSqlReaderStoredProcedureName("datapvnvdzssssn")
- .withStoredProcedureParameters("datahgid")
- .withIsolationLevel("dataotx")
- .withPartitionOption("databxzhad")
- .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datannootc")
- .withPartitionUpperBound("dataupaq")
- .withPartitionLowerBound("dataodhnzkmjoyby"));
+ WarehouseSource model = new WarehouseSource().withSourceRetryCount("dataxoic")
+ .withSourceRetryWait("datasmfvltbocqhv")
+ .withMaxConcurrentConnections("datam")
+ .withDisableMetricsCollection("datapvgri")
+ .withQueryTimeout("dataiottdawgkaohhtt")
+ .withAdditionalColumns("datahypidzjjjfcyskpn")
+ .withSqlReaderQuery("dataophtkyzsgayng")
+ .withSqlReaderStoredProcedureName("datawvcnv")
+ .withStoredProcedureParameters("dataqxqhysu")
+ .withIsolationLevel("datadnslroqxrvycjdn")
+ .withPartitionOption("datamggy")
+ .withPartitionSettings(new SqlPartitionSettings().withPartitionColumnName("datamsacbamtoqseam")
+ .withPartitionUpperBound("dataxdigkggzmylq")
+ .withPartitionLowerBound("dataeosxdsxil"));
model = BinaryData.fromObject(model).toObject(WarehouseSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTests.java
index 1b7c1d25314c..0c8a634bf726 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTests.java
@@ -19,33 +19,33 @@ public final class WarehouseTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WarehouseTableDataset model = BinaryData.fromString(
- "{\"type\":\"WarehouseTable\",\"typeProperties\":{\"schema\":\"datauoqhqrcsksxqfhl\",\"table\":\"datauvdagvyjcdpncv\"},\"description\":\"eqyodii\",\"structure\":\"datasapqhipajsniv\",\"schema\":\"dataevlj\",\"linkedServiceName\":{\"referenceName\":\"cuwrfgpjfv\",\"parameters\":{\"ykzzugctygbb\":\"dataseodvlmdzgv\",\"ljvvcrsmw\":\"datau\",\"jftvltj\":\"datajmxwcvumnrutqnke\",\"pkbzltnowpajf\":\"datapec\"}},\"parameters\":{\"suhsypx\":{\"type\":\"Int\",\"defaultValue\":\"databbzadzglmuuz\"}},\"annotations\":[\"datadhf\",\"dataerkqpyfj\",\"datakbyws\"],\"folder\":{\"name\":\"fmxbdjkm\"},\"\":{\"vghbtycvl\":\"dataggnowxhyvdbrdv\",\"xshmrdisc\":\"datausgiikhrcthype\"}}")
+ "{\"type\":\"WarehouseTable\",\"typeProperties\":{\"schema\":\"datajpj\",\"table\":\"datajdtuodoc\"},\"description\":\"u\",\"structure\":\"datanyxpmqd\",\"schema\":\"dataniiontqikdipkxs\",\"linkedServiceName\":{\"referenceName\":\"kuzabrsoih\",\"parameters\":{\"oadoh\":\"datajdtacvsynssxylsu\",\"wlxqdsxip\":\"datajyiehkxgfuzqqnz\",\"wwgze\":\"datanlbyitfz\",\"joygyn\":\"datalzpiimxacrk\"}},\"parameters\":{\"lquarbruvqb\":{\"type\":\"Object\",\"defaultValue\":\"databbnu\"}},\"annotations\":[\"datawrmu\",\"datazpexzbhgjaj\"],\"folder\":{\"name\":\"koc\"},\"\":{\"vnatbgvlpgf\":\"datadzl\",\"akybepsihz\":\"datagen\",\"gl\":\"dataieoymp\",\"zlycxlubrukhqb\":\"datajsfgbyyts\"}}")
.toObject(WarehouseTableDataset.class);
- Assertions.assertEquals("eqyodii", model.description());
- Assertions.assertEquals("cuwrfgpjfv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("suhsypx").type());
- Assertions.assertEquals("fmxbdjkm", model.folder().name());
+ Assertions.assertEquals("u", model.description());
+ Assertions.assertEquals("kuzabrsoih", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("lquarbruvqb").type());
+ Assertions.assertEquals("koc", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WarehouseTableDataset model = new WarehouseTableDataset().withDescription("eqyodii")
- .withStructure("datasapqhipajsniv")
- .withSchema("dataevlj")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("cuwrfgpjfv")
- .withParameters(mapOf("ykzzugctygbb", "dataseodvlmdzgv", "ljvvcrsmw", "datau", "jftvltj",
- "datajmxwcvumnrutqnke", "pkbzltnowpajf", "datapec")))
- .withParameters(mapOf("suhsypx",
- new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("databbzadzglmuuz")))
- .withAnnotations(Arrays.asList("datadhf", "dataerkqpyfj", "datakbyws"))
- .withFolder(new DatasetFolder().withName("fmxbdjkm"))
- .withSchemaTypePropertiesSchema("datauoqhqrcsksxqfhl")
- .withTable("datauvdagvyjcdpncv");
+ WarehouseTableDataset model = new WarehouseTableDataset().withDescription("u")
+ .withStructure("datanyxpmqd")
+ .withSchema("dataniiontqikdipkxs")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("kuzabrsoih")
+ .withParameters(mapOf("oadoh", "datajdtacvsynssxylsu", "wlxqdsxip", "datajyiehkxgfuzqqnz", "wwgze",
+ "datanlbyitfz", "joygyn", "datalzpiimxacrk")))
+ .withParameters(mapOf("lquarbruvqb",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("databbnu")))
+ .withAnnotations(Arrays.asList("datawrmu", "datazpexzbhgjaj"))
+ .withFolder(new DatasetFolder().withName("koc"))
+ .withSchemaTypePropertiesSchema("datajpj")
+ .withTable("datajdtuodoc");
model = BinaryData.fromObject(model).toObject(WarehouseTableDataset.class);
- Assertions.assertEquals("eqyodii", model.description());
- Assertions.assertEquals("cuwrfgpjfv", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.INT, model.parameters().get("suhsypx").type());
- Assertions.assertEquals("fmxbdjkm", model.folder().name());
+ Assertions.assertEquals("u", model.description());
+ Assertions.assertEquals("kuzabrsoih", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("lquarbruvqb").type());
+ Assertions.assertEquals("koc", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTypePropertiesTests.java
index fa6601f82f1e..c65e7a784da7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WarehouseTableDatasetTypePropertiesTests.java
@@ -11,15 +11,14 @@ public final class WarehouseTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WarehouseTableDatasetTypeProperties model
- = BinaryData.fromString("{\"schema\":\"datavkymktcwmivoxgze\",\"table\":\"dataglafnfgazaghddc\"}")
+ = BinaryData.fromString("{\"schema\":\"datayrbdkgqdmvvvjm\",\"table\":\"datajf\"}")
.toObject(WarehouseTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
WarehouseTableDatasetTypeProperties model
- = new WarehouseTableDatasetTypeProperties().withSchema("datavkymktcwmivoxgze")
- .withTable("dataglafnfgazaghddc");
+ = new WarehouseTableDatasetTypeProperties().withSchema("datayrbdkgqdmvvvjm").withTable("datajf");
model = BinaryData.fromObject(model).toObject(WarehouseTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebAnonymousAuthenticationTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebAnonymousAuthenticationTests.java
index e6d27cda93e9..a7460d18ce35 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebAnonymousAuthenticationTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebAnonymousAuthenticationTests.java
@@ -11,13 +11,13 @@ public final class WebAnonymousAuthenticationTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WebAnonymousAuthentication model
- = BinaryData.fromString("{\"authenticationType\":\"Anonymous\",\"url\":\"datar\"}")
+ = BinaryData.fromString("{\"authenticationType\":\"Anonymous\",\"url\":\"dataayooghj\"}")
.toObject(WebAnonymousAuthentication.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WebAnonymousAuthentication model = new WebAnonymousAuthentication().withUrl("datar");
+ WebAnonymousAuthentication model = new WebAnonymousAuthentication().withUrl("dataayooghj");
model = BinaryData.fromObject(model).toObject(WebAnonymousAuthentication.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTests.java
index 3b956420919f..1efb9cf84150 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTests.java
@@ -19,30 +19,29 @@ public final class WebLinkedServiceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WebLinkedService model = BinaryData.fromString(
- "{\"type\":\"Web\",\"typeProperties\":{\"authenticationType\":\"WebLinkedServiceTypeProperties\",\"url\":\"datakhmsobu\"},\"version\":\"okiclrmmudvo\",\"connectVia\":{\"referenceName\":\"bscidkwznw\",\"parameters\":{\"ybcppdvuotkvk\":\"dataizdoysmzgbogdjw\"}},\"description\":\"mkupbnkcwauyl\",\"parameters\":{\"afqzylempah\":{\"type\":\"SecureString\",\"defaultValue\":\"datarpyfrtlu\"},\"pwrnhqaf\":{\"type\":\"Array\",\"defaultValue\":\"dataxeikeo\"}},\"annotations\":[\"dataysp\",\"datajkxgfmesxjeqqfy\",\"datav\",\"datakxtanlvoorv\"],\"\":{\"tps\":\"datancqcu\",\"egxlzd\":\"datagqlnolspvxp\",\"smnwsffia\":\"dataatptzkmfvdrkcw\"}}")
+ "{\"type\":\"Web\",\"typeProperties\":{\"authenticationType\":\"WebLinkedServiceTypeProperties\",\"url\":\"datacg\"},\"version\":\"t\",\"connectVia\":{\"referenceName\":\"lpihtepasjeb\",\"parameters\":{\"nybnt\":\"datavfcdsijs\",\"ayxujzoxgakqt\":\"datax\"}},\"description\":\"jucazwedmahulxgc\",\"parameters\":{\"dvqan\":{\"type\":\"Array\",\"defaultValue\":\"datan\"}},\"annotations\":[\"dataxgohm\",\"datagblqyf\"],\"\":{\"zfgxwfxjiqp\":\"datafpqifs\"}}")
.toObject(WebLinkedService.class);
- Assertions.assertEquals("okiclrmmudvo", model.version());
- Assertions.assertEquals("bscidkwznw", model.connectVia().referenceName());
- Assertions.assertEquals("mkupbnkcwauyl", model.description());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("afqzylempah").type());
+ Assertions.assertEquals("t", model.version());
+ Assertions.assertEquals("lpihtepasjeb", model.connectVia().referenceName());
+ Assertions.assertEquals("jucazwedmahulxgc", model.description());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("dvqan").type());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WebLinkedService model = new WebLinkedService().withVersion("okiclrmmudvo")
- .withConnectVia(new IntegrationRuntimeReference().withReferenceName("bscidkwznw")
- .withParameters(mapOf("ybcppdvuotkvk", "dataizdoysmzgbogdjw")))
- .withDescription("mkupbnkcwauyl")
- .withParameters(mapOf("afqzylempah",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING).withDefaultValue("datarpyfrtlu"),
- "pwrnhqaf", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("dataxeikeo")))
- .withAnnotations(Arrays.asList("dataysp", "datajkxgfmesxjeqqfy", "datav", "datakxtanlvoorv"))
- .withTypeProperties(new WebLinkedServiceTypeProperties().withUrl("datakhmsobu"));
+ WebLinkedService model = new WebLinkedService().withVersion("t")
+ .withConnectVia(new IntegrationRuntimeReference().withReferenceName("lpihtepasjeb")
+ .withParameters(mapOf("nybnt", "datavfcdsijs", "ayxujzoxgakqt", "datax")))
+ .withDescription("jucazwedmahulxgc")
+ .withParameters(
+ mapOf("dvqan", new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datan")))
+ .withAnnotations(Arrays.asList("dataxgohm", "datagblqyf"))
+ .withTypeProperties(new WebLinkedServiceTypeProperties().withUrl("datacg"));
model = BinaryData.fromObject(model).toObject(WebLinkedService.class);
- Assertions.assertEquals("okiclrmmudvo", model.version());
- Assertions.assertEquals("bscidkwznw", model.connectVia().referenceName());
- Assertions.assertEquals("mkupbnkcwauyl", model.description());
- Assertions.assertEquals(ParameterType.SECURE_STRING, model.parameters().get("afqzylempah").type());
+ Assertions.assertEquals("t", model.version());
+ Assertions.assertEquals("lpihtepasjeb", model.connectVia().referenceName());
+ Assertions.assertEquals("jucazwedmahulxgc", model.description());
+ Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("dvqan").type());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTypePropertiesTests.java
index 9fa96c4031bd..23549c5d134f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebLinkedServiceTypePropertiesTests.java
@@ -11,13 +11,13 @@ public final class WebLinkedServiceTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WebLinkedServiceTypeProperties model
- = BinaryData.fromString("{\"authenticationType\":\"WebLinkedServiceTypeProperties\",\"url\":\"datafd\"}")
+ = BinaryData.fromString("{\"authenticationType\":\"WebLinkedServiceTypeProperties\",\"url\":\"datasohwn\"}")
.toObject(WebLinkedServiceTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WebLinkedServiceTypeProperties model = new WebLinkedServiceTypeProperties().withUrl("datafd");
+ WebLinkedServiceTypeProperties model = new WebLinkedServiceTypeProperties().withUrl("datasohwn");
model = BinaryData.fromObject(model).toObject(WebLinkedServiceTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebSourceTests.java
index 7e772b9b8760..dc02f6f401c7 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebSourceTests.java
@@ -11,17 +11,17 @@ public final class WebSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WebSource model = BinaryData.fromString(
- "{\"type\":\"WebSource\",\"additionalColumns\":\"dataonnr\",\"sourceRetryCount\":\"datahoygzkdbmjzobcdv\",\"sourceRetryWait\":\"datauuipelokptt\",\"maxConcurrentConnections\":\"datajxhwg\",\"disableMetricsCollection\":\"datahxgrpwjg\",\"\":{\"tzxsvwqiwgjwrhu\":\"datakjdhslnqmmw\",\"tt\":\"datagaaaxigafa\"}}")
+ "{\"type\":\"WebSource\",\"additionalColumns\":\"datavifl\",\"sourceRetryCount\":\"datarknsc\",\"sourceRetryWait\":\"datah\",\"maxConcurrentConnections\":\"dataljsvpokvh\",\"disableMetricsCollection\":\"dataygffuzhnusrfffag\",\"\":{\"hgonovwu\":\"datafwzysvnvrfjgbxup\",\"gkouf\":\"dataearowrmesziubkyv\"}}")
.toObject(WebSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WebSource model = new WebSource().withSourceRetryCount("datahoygzkdbmjzobcdv")
- .withSourceRetryWait("datauuipelokptt")
- .withMaxConcurrentConnections("datajxhwg")
- .withDisableMetricsCollection("datahxgrpwjg")
- .withAdditionalColumns("dataonnr");
+ WebSource model = new WebSource().withSourceRetryCount("datarknsc")
+ .withSourceRetryWait("datah")
+ .withMaxConcurrentConnections("dataljsvpokvh")
+ .withDisableMetricsCollection("dataygffuzhnusrfffag")
+ .withAdditionalColumns("datavifl");
model = BinaryData.fromObject(model).toObject(WebSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTests.java
index fe5fa6efb89a..f27048613fb8 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTests.java
@@ -19,35 +19,33 @@ public final class WebTableDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WebTableDataset model = BinaryData.fromString(
- "{\"type\":\"WebTable\",\"typeProperties\":{\"index\":\"datavapeakfdmc\",\"path\":\"datal\"},\"description\":\"lxkyoddoq\",\"structure\":\"datanqtrkicwhqyr\",\"schema\":\"datamndkrwwmurhvif\",\"linkedServiceName\":{\"referenceName\":\"eqfsrnackitl\",\"parameters\":{\"juniln\":\"databylpzjeldaq\",\"tnpkbvzpk\":\"datajhwcbrdsyp\",\"ldxuczlhvbqyczn\":\"datadngvnqdjgsbtwg\"}},\"parameters\":{\"g\":{\"type\":\"String\",\"defaultValue\":\"dataiuvcqoqkqwucqs\"},\"myvwp\":{\"type\":\"Object\",\"defaultValue\":\"datawtvmijccpkkjl\"}},\"annotations\":[\"dataaih\",\"datannlb\",\"dataxjppcbqetfzfppv\",\"datalzayjwdun\"],\"folder\":{\"name\":\"prklatwiuujxsuj\"},\"\":{\"cymgbfmdquyyaes\":\"datagxeegxbnjnczepd\",\"kihai\":\"datajxnavpyxqbkxdtb\",\"ozcgoeozlib\":\"datazkefkzlxv\"}}")
+ "{\"type\":\"WebTable\",\"typeProperties\":{\"index\":\"dataojzdvmsnao\",\"path\":\"datasxoxvim\"},\"description\":\"etqhdbitqsby\",\"structure\":\"datasgomrihumg\",\"schema\":\"datasdbvq\",\"linkedServiceName\":{\"referenceName\":\"gfygfkgxbdpb\",\"parameters\":{\"porrvkxtfctane\":\"datawbdpsesboynpy\",\"g\":\"datainqxdhnpjnezj\",\"uxvf\":\"datadumltpmrzwvwetqf\",\"lmr\":\"datauqhngqqxjbsoto\"}},\"parameters\":{\"xedhxbboceksra\":{\"type\":\"Object\",\"defaultValue\":\"datadeatwxpx\"}},\"annotations\":[\"datahlugfnlvvk\"],\"folder\":{\"name\":\"rxdqhvhauimn\"},\"\":{\"ivlqcwyzhndqkzst\":\"datakqpwqcnbn\",\"u\":\"datapzecdlceirtah\"}}")
.toObject(WebTableDataset.class);
- Assertions.assertEquals("lxkyoddoq", model.description());
- Assertions.assertEquals("eqfsrnackitl", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("g").type());
- Assertions.assertEquals("prklatwiuujxsuj", model.folder().name());
+ Assertions.assertEquals("etqhdbitqsby", model.description());
+ Assertions.assertEquals("gfygfkgxbdpb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xedhxbboceksra").type());
+ Assertions.assertEquals("rxdqhvhauimn", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- WebTableDataset model = new WebTableDataset().withDescription("lxkyoddoq")
- .withStructure("datanqtrkicwhqyr")
- .withSchema("datamndkrwwmurhvif")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("eqfsrnackitl")
- .withParameters(mapOf("juniln", "databylpzjeldaq", "tnpkbvzpk", "datajhwcbrdsyp", "ldxuczlhvbqyczn",
- "datadngvnqdjgsbtwg")))
- .withParameters(mapOf("g",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataiuvcqoqkqwucqs"),
- "myvwp",
- new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datawtvmijccpkkjl")))
- .withAnnotations(Arrays.asList("dataaih", "datannlb", "dataxjppcbqetfzfppv", "datalzayjwdun"))
- .withFolder(new DatasetFolder().withName("prklatwiuujxsuj"))
- .withIndex("datavapeakfdmc")
- .withPath("datal");
+ WebTableDataset model = new WebTableDataset().withDescription("etqhdbitqsby")
+ .withStructure("datasgomrihumg")
+ .withSchema("datasdbvq")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("gfygfkgxbdpb")
+ .withParameters(mapOf("porrvkxtfctane", "datawbdpsesboynpy", "g", "datainqxdhnpjnezj", "uxvf",
+ "datadumltpmrzwvwetqf", "lmr", "datauqhngqqxjbsoto")))
+ .withParameters(mapOf("xedhxbboceksra",
+ new ParameterSpecification().withType(ParameterType.OBJECT).withDefaultValue("datadeatwxpx")))
+ .withAnnotations(Arrays.asList("datahlugfnlvvk"))
+ .withFolder(new DatasetFolder().withName("rxdqhvhauimn"))
+ .withIndex("dataojzdvmsnao")
+ .withPath("datasxoxvim");
model = BinaryData.fromObject(model).toObject(WebTableDataset.class);
- Assertions.assertEquals("lxkyoddoq", model.description());
- Assertions.assertEquals("eqfsrnackitl", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("g").type());
- Assertions.assertEquals("prklatwiuujxsuj", model.folder().name());
+ Assertions.assertEquals("etqhdbitqsby", model.description());
+ Assertions.assertEquals("gfygfkgxbdpb", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.OBJECT, model.parameters().get("xedhxbboceksra").type());
+ Assertions.assertEquals("rxdqhvhauimn", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTypePropertiesTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTypePropertiesTests.java
index 31fd77628213..bd92abb75493 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTypePropertiesTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/WebTableDatasetTypePropertiesTests.java
@@ -11,14 +11,14 @@ public final class WebTableDatasetTypePropertiesTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
WebTableDatasetTypeProperties model
- = BinaryData.fromString("{\"index\":\"databnunzuysajvvqlho\",\"path\":\"dataon\"}")
+ = BinaryData.fromString("{\"index\":\"datacimtcaumviud\",\"path\":\"datasjqrmlujmtun\"}")
.toObject(WebTableDatasetTypeProperties.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
WebTableDatasetTypeProperties model
- = new WebTableDatasetTypeProperties().withIndex("databnunzuysajvvqlho").withPath("dataon");
+ = new WebTableDatasetTypeProperties().withIndex("datacimtcaumviud").withPath("datasjqrmlujmtun");
model = BinaryData.fromObject(model).toObject(WebTableDatasetTypeProperties.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroObjectDatasetTests.java
index 37696c391ed0..7bf825a03b3e 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroObjectDatasetTests.java
@@ -19,34 +19,32 @@ public final class XeroObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
XeroObjectDataset model = BinaryData.fromString(
- "{\"type\":\"XeroObject\",\"typeProperties\":{\"tableName\":\"datadnpfcghdttowqx\"},\"description\":\"pbzxpzl\",\"structure\":\"datavhatiywtcvzuzp\",\"schema\":\"dataeomotq\",\"linkedServiceName\":{\"referenceName\":\"ql\",\"parameters\":{\"gq\":\"datai\",\"dpfvlsqmmetwtla\":\"datazk\"}},\"parameters\":{\"cgrllyyfsmoc\":{\"type\":\"String\",\"defaultValue\":\"dataefbdpnuvh\"},\"kgdskwvb\":{\"type\":\"SecureString\",\"defaultValue\":\"datarchmetvzhuugd\"}},\"annotations\":[\"datawwayqts\",\"datanyotgnmze\",\"datacreluedcmk\"],\"folder\":{\"name\":\"heexzhhllxwk\"},\"\":{\"tkqiymmddslwnlg\":\"dataxdjklfsd\",\"ybnnnlpqdnnska\":\"datadlhmks\"}}")
+ "{\"type\":\"XeroObject\",\"typeProperties\":{\"tableName\":\"datamjcoyvfwgkzuhksh\"},\"description\":\"kckwbqwjyfmmkwa\",\"structure\":\"dataooyzhob\",\"schema\":\"datayuepaco\",\"linkedServiceName\":{\"referenceName\":\"rohextigukf\",\"parameters\":{\"ymbnpeenlqtqyv\":\"dataycb\",\"avqdvfjdsqephtos\":\"datafb\",\"jwgujrc\":\"dataqtua\"}},\"parameters\":{\"wscjwyyeomifl\":{\"type\":\"Float\",\"defaultValue\":\"datapyqoizfyasyddq\"}},\"annotations\":[\"dataeowctshwfrhhas\",\"databvau\",\"datanwwumkbpg\",\"datailbwtpwbjlpfwuq\"],\"folder\":{\"name\":\"dgi\"},\"\":{\"plan\":\"datayukslizmpnxgham\"}}")
.toObject(XeroObjectDataset.class);
- Assertions.assertEquals("pbzxpzl", model.description());
- Assertions.assertEquals("ql", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("cgrllyyfsmoc").type());
- Assertions.assertEquals("heexzhhllxwk", model.folder().name());
+ Assertions.assertEquals("kckwbqwjyfmmkwa", model.description());
+ Assertions.assertEquals("rohextigukf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("wscjwyyeomifl").type());
+ Assertions.assertEquals("dgi", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- XeroObjectDataset model = new XeroObjectDataset().withDescription("pbzxpzl")
- .withStructure("datavhatiywtcvzuzp")
- .withSchema("dataeomotq")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("ql")
- .withParameters(mapOf("gq", "datai", "dpfvlsqmmetwtla", "datazk")))
- .withParameters(mapOf("cgrllyyfsmoc",
- new ParameterSpecification().withType(ParameterType.STRING).withDefaultValue("dataefbdpnuvh"),
- "kgdskwvb",
- new ParameterSpecification().withType(ParameterType.SECURE_STRING)
- .withDefaultValue("datarchmetvzhuugd")))
- .withAnnotations(Arrays.asList("datawwayqts", "datanyotgnmze", "datacreluedcmk"))
- .withFolder(new DatasetFolder().withName("heexzhhllxwk"))
- .withTableName("datadnpfcghdttowqx");
+ XeroObjectDataset model = new XeroObjectDataset().withDescription("kckwbqwjyfmmkwa")
+ .withStructure("dataooyzhob")
+ .withSchema("datayuepaco")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("rohextigukf")
+ .withParameters(
+ mapOf("ymbnpeenlqtqyv", "dataycb", "avqdvfjdsqephtos", "datafb", "jwgujrc", "dataqtua")))
+ .withParameters(mapOf("wscjwyyeomifl",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("datapyqoizfyasyddq")))
+ .withAnnotations(Arrays.asList("dataeowctshwfrhhas", "databvau", "datanwwumkbpg", "datailbwtpwbjlpfwuq"))
+ .withFolder(new DatasetFolder().withName("dgi"))
+ .withTableName("datamjcoyvfwgkzuhksh");
model = BinaryData.fromObject(model).toObject(XeroObjectDataset.class);
- Assertions.assertEquals("pbzxpzl", model.description());
- Assertions.assertEquals("ql", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.STRING, model.parameters().get("cgrllyyfsmoc").type());
- Assertions.assertEquals("heexzhhllxwk", model.folder().name());
+ Assertions.assertEquals("kckwbqwjyfmmkwa", model.description());
+ Assertions.assertEquals("rohextigukf", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.FLOAT, model.parameters().get("wscjwyyeomifl").type());
+ Assertions.assertEquals("dgi", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroSourceTests.java
index e8d8c025726b..c7de1b46e841 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XeroSourceTests.java
@@ -11,19 +11,19 @@ public final class XeroSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
XeroSource model = BinaryData.fromString(
- "{\"type\":\"XeroSource\",\"query\":\"dataeycakkon\",\"queryTimeout\":\"datadpd\",\"additionalColumns\":\"datahadzyxaanhwuqewc\",\"sourceRetryCount\":\"datasksfbkxfkeeqo\",\"sourceRetryWait\":\"databek\",\"maxConcurrentConnections\":\"dataerwss\",\"disableMetricsCollection\":\"datamrpdjrylfpdudx\",\"\":{\"tqssngeviyffg\":\"dataeuriehxbanfsqfh\",\"hdapynpvgyaf\":\"datahrhjsps\"}}")
+ "{\"type\":\"XeroSource\",\"query\":\"datahegcolh\",\"queryTimeout\":\"datacklqrunqwcrkkaby\",\"additionalColumns\":\"datay\",\"sourceRetryCount\":\"dataipywgjgfbsfsva\",\"sourceRetryWait\":\"dataejypokk\",\"maxConcurrentConnections\":\"datatnwpwskckc\",\"disableMetricsCollection\":\"datamfyxpgvqioqrebwa\",\"\":{\"reqaqvspsy\":\"dataplkpemxc\"}}")
.toObject(XeroSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- XeroSource model = new XeroSource().withSourceRetryCount("datasksfbkxfkeeqo")
- .withSourceRetryWait("databek")
- .withMaxConcurrentConnections("dataerwss")
- .withDisableMetricsCollection("datamrpdjrylfpdudx")
- .withQueryTimeout("datadpd")
- .withAdditionalColumns("datahadzyxaanhwuqewc")
- .withQuery("dataeycakkon");
+ XeroSource model = new XeroSource().withSourceRetryCount("dataipywgjgfbsfsva")
+ .withSourceRetryWait("dataejypokk")
+ .withMaxConcurrentConnections("datatnwpwskckc")
+ .withDisableMetricsCollection("datamfyxpgvqioqrebwa")
+ .withQueryTimeout("datacklqrunqwcrkkaby")
+ .withAdditionalColumns("datay")
+ .withQuery("datahegcolh");
model = BinaryData.fromObject(model).toObject(XeroSource.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlReadSettingsTests.java
index 7305b802cca6..5b560cee432f 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlReadSettingsTests.java
@@ -14,7 +14,7 @@ public final class XmlReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
XmlReadSettings model = BinaryData.fromString(
- "{\"type\":\"XmlReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"byvsfqu\":\"datanadykmvou\",\"xqbknoxjhedwh\":\"datar\",\"rpajbiig\":\"datamwb\"}},\"validationMode\":\"datarezpuzkwi\",\"detectDataType\":\"datafin\",\"namespaces\":\"datasdtlpshxjhans\",\"namespacePrefixes\":\"dataoalcnkgqs\",\"\":{\"ksstaljiqlxjjlt\":\"datay\",\"anddlvccuvc\":\"dataymnaaqhsc\",\"jgdjvyclas\":\"dataaflsb\"}}")
+ "{\"type\":\"XmlReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"mdrmasvghphlbk\":\"datae\",\"mviaasdexsrglxlj\":\"datauhmblni\",\"spdipdxq\":\"datayvkkpovz\",\"wvilky\":\"datapdjomddadwosjxy\"}},\"validationMode\":\"datan\",\"detectDataType\":\"datayhdb\",\"namespaces\":\"datagsjmcybrpwjenb\",\"namespacePrefixes\":\"datakghrrxauuhd\",\"\":{\"wip\":\"dataizyxoyxnhub\",\"ezzyrp\":\"dataryiv\"}}")
.toObject(XmlReadSettings.class);
}
@@ -23,10 +23,10 @@ public void testSerialize() throws Exception {
XmlReadSettings model = new XmlReadSettings()
.withCompressionProperties(
new CompressionReadSettings().withAdditionalProperties(mapOf("type", "CompressionReadSettings")))
- .withValidationMode("datarezpuzkwi")
- .withDetectDataType("datafin")
- .withNamespaces("datasdtlpshxjhans")
- .withNamespacePrefixes("dataoalcnkgqs");
+ .withValidationMode("datan")
+ .withDetectDataType("datayhdb")
+ .withNamespaces("datagsjmcybrpwjenb")
+ .withNamespacePrefixes("datakghrrxauuhd");
model = BinaryData.fromObject(model).toObject(XmlReadSettings.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlSourceTests.java
index d8a83f9a5fff..18eca6f04253 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/XmlSourceTests.java
@@ -16,27 +16,27 @@ public final class XmlSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
XmlSource model = BinaryData.fromString(
- "{\"type\":\"XmlSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datasljkaarqhpxwq\",\"disableMetricsCollection\":\"datasxgmgvygmtyw\",\"\":{\"rsxykw\":\"datauiteedjnklv\",\"dudj\":\"datahz\",\"qxpsnnn\":\"datat\",\"sdxylndbgaic\":\"datahgd\"}},\"formatSettings\":{\"type\":\"XmlReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"mrxjdfkqlkaipf\":\"datafzkhdnp\",\"vakqaho\":\"datavquasvywkbiek\"}},\"validationMode\":\"datanapkpaied\",\"detectDataType\":\"datavoaoavezwclmzm\",\"namespaces\":\"datavlghlrcdiq\",\"namespacePrefixes\":\"datahcb\",\"\":{\"fjtockgqaawyysz\":\"datawif\",\"lwfqrfy\":\"dataoeql\"}},\"additionalColumns\":\"datazsipkhqhvktc\",\"sourceRetryCount\":\"datamqdkhoh\",\"sourceRetryWait\":\"datakgxemvlyapr\",\"maxConcurrentConnections\":\"databxxxqfrn\",\"disableMetricsCollection\":\"databhmxlpxf\",\"\":{\"vfapfbmrwh\":\"datagtoinozsmy\",\"pdd\":\"datanefcooptmd\",\"laxuybxjwny\":\"datagupiosibg\"}}")
+ "{\"type\":\"XmlSource\",\"storeSettings\":{\"type\":\"StoreReadSettings\",\"maxConcurrentConnections\":\"datalpkocre\",\"disableMetricsCollection\":\"datamqfuflupuvwl\",\"\":{\"gzscgslwujk\":\"datarjglacp\"}},\"formatSettings\":{\"type\":\"XmlReadSettings\",\"compressionProperties\":{\"type\":\"CompressionReadSettings\",\"\":{\"jnnbmods\":\"datal\",\"atujphqvfxvv\":\"datatqt\",\"fnwdrmzwmtsmeac\":\"datagwghxoxwpiqkkm\",\"mgnvcusvidkzbd\":\"dataypkhnr\"}},\"validationMode\":\"datalsnch\",\"detectDataType\":\"datarfomlh\",\"namespaces\":\"dataiktecs\",\"namespacePrefixes\":\"datacqweydaa\",\"\":{\"iwfsqjxxbsafqiw\":\"datatmfcx\",\"g\":\"dataduotsyjzda\"}},\"additionalColumns\":\"datazpr\",\"sourceRetryCount\":\"dataom\",\"sourceRetryWait\":\"dataohnpkofklbd\",\"maxConcurrentConnections\":\"datanzmffyvowlammvaz\",\"disableMetricsCollection\":\"datazie\",\"\":{\"hjxdnkgztfgcuz\":\"dataunmgdpxeiv\",\"eiidfpwbybmxf\":\"databrehdtqggzahngnr\"}}")
.toObject(XmlSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- XmlSource model = new XmlSource().withSourceRetryCount("datamqdkhoh")
- .withSourceRetryWait("datakgxemvlyapr")
- .withMaxConcurrentConnections("databxxxqfrn")
- .withDisableMetricsCollection("databhmxlpxf")
- .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datasljkaarqhpxwq")
- .withDisableMetricsCollection("datasxgmgvygmtyw")
+ XmlSource model = new XmlSource().withSourceRetryCount("dataom")
+ .withSourceRetryWait("dataohnpkofklbd")
+ .withMaxConcurrentConnections("datanzmffyvowlammvaz")
+ .withDisableMetricsCollection("datazie")
+ .withStoreSettings(new StoreReadSettings().withMaxConcurrentConnections("datalpkocre")
+ .withDisableMetricsCollection("datamqfuflupuvwl")
.withAdditionalProperties(mapOf("type", "StoreReadSettings")))
.withFormatSettings(new XmlReadSettings()
.withCompressionProperties(
new CompressionReadSettings().withAdditionalProperties(mapOf("type", "CompressionReadSettings")))
- .withValidationMode("datanapkpaied")
- .withDetectDataType("datavoaoavezwclmzm")
- .withNamespaces("datavlghlrcdiq")
- .withNamespacePrefixes("datahcb"))
- .withAdditionalColumns("datazsipkhqhvktc");
+ .withValidationMode("datalsnch")
+ .withDetectDataType("datarfomlh")
+ .withNamespaces("dataiktecs")
+ .withNamespacePrefixes("datacqweydaa"))
+ .withAdditionalColumns("datazpr");
model = BinaryData.fromObject(model).toObject(XmlSource.class);
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZipDeflateReadSettingsTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZipDeflateReadSettingsTests.java
index 817f225c5146..4381adf1ee17 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZipDeflateReadSettingsTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZipDeflateReadSettingsTests.java
@@ -11,13 +11,13 @@ public final class ZipDeflateReadSettingsTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ZipDeflateReadSettings model = BinaryData.fromString(
- "{\"type\":\"ZipDeflateReadSettings\",\"preserveZipFileNameAsFolder\":\"dataexzyjf\",\"\":{\"tgxdlznfo\":\"datavmq\",\"pp\":\"datacbxrskylq\",\"tsygzjplaxxfnrlt\":\"datateikktret\",\"rotg\":\"datanvb\"}}")
+ "{\"type\":\"ZipDeflateReadSettings\",\"preserveZipFileNameAsFolder\":\"datajxwwqz\",\"\":{\"vwznwcq\":\"datatbffrhq\",\"jkltetfdpurvz\":\"dataapd\",\"sfu\":\"datatjb\",\"qhbwsv\":\"dataedsaafk\"}}")
.toObject(ZipDeflateReadSettings.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ZipDeflateReadSettings model = new ZipDeflateReadSettings().withPreserveZipFileNameAsFolder("dataexzyjf");
+ ZipDeflateReadSettings model = new ZipDeflateReadSettings().withPreserveZipFileNameAsFolder("datajxwwqz");
model = BinaryData.fromObject(model).toObject(ZipDeflateReadSettings.class);
}
}
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoObjectDatasetTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoObjectDatasetTests.java
index 2cb8d2ec2616..d53aa8e81b70 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoObjectDatasetTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoObjectDatasetTests.java
@@ -19,34 +19,33 @@ public final class ZohoObjectDatasetTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ZohoObjectDataset model = BinaryData.fromString(
- "{\"type\":\"ZohoObject\",\"typeProperties\":{\"tableName\":\"datamrslwknrd\"},\"description\":\"mbjern\",\"structure\":\"datazywx\",\"schema\":\"dataaq\",\"linkedServiceName\":{\"referenceName\":\"tkdeetnnef\",\"parameters\":{\"fwqjzybmfqdnpp\":\"datalkszuxjmrzsxwa\",\"vamuvkgd\":\"datacfguam\",\"spjvsyydjlhd\":\"datapjbblukgctv\"}},\"parameters\":{\"ulojwumfjdymeq\":{\"type\":\"Array\",\"defaultValue\":\"datavyeegx\"},\"nxemhqpzhnatw\":{\"type\":\"Bool\",\"defaultValue\":\"datapfyxdjspn\"}},\"annotations\":[\"datamcvdjlwwefevtwll\",\"dataypmjc\",\"datay\",\"datafwgkzuhk\"],\"folder\":{\"name\":\"jkckwbqwjyfmmk\"},\"\":{\"oerohextigukfk\":\"datarooyzhobnvyuepa\",\"enlqtqyvlfbs\":\"datasycbdymbnp\"}}")
+ "{\"type\":\"ZohoObject\",\"typeProperties\":{\"tableName\":\"dataotmmxlmxejwyv\"},\"description\":\"b\",\"structure\":\"datavtuekbb\",\"schema\":\"dataqsm\",\"linkedServiceName\":{\"referenceName\":\"sbeqieiuxhj\",\"parameters\":{\"lzyxvtajfjatoid\":\"datadalnjjhrgkjjpcpi\",\"gnpuelrnanbrpkoc\":\"dataekurdgcpzanaqve\"}},\"parameters\":{\"gijxmdboe\":{\"type\":\"Int\",\"defaultValue\":\"datagegjtjltckiwxggf\"},\"u\":{\"type\":\"Float\",\"defaultValue\":\"dataxha\"}},\"annotations\":[\"datanvzsodmokrqd\",\"datasgkq\"],\"folder\":{\"name\":\"otypcjxh\"},\"\":{\"p\":\"datalocjhz\",\"xbofpr\":\"databrbm\",\"wwsfvtgh\":\"datamivapesbfzllej\"}}")
.toObject(ZohoObjectDataset.class);
- Assertions.assertEquals("mbjern", model.description());
- Assertions.assertEquals("tkdeetnnef", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ulojwumfjdymeq").type());
- Assertions.assertEquals("jkckwbqwjyfmmk", model.folder().name());
+ Assertions.assertEquals("b", model.description());
+ Assertions.assertEquals("sbeqieiuxhj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("gijxmdboe").type());
+ Assertions.assertEquals("otypcjxh", model.folder().name());
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ZohoObjectDataset model = new ZohoObjectDataset().withDescription("mbjern")
- .withStructure("datazywx")
- .withSchema("dataaq")
- .withLinkedServiceName(new LinkedServiceReference().withReferenceName("tkdeetnnef")
- .withParameters(mapOf("fwqjzybmfqdnpp", "datalkszuxjmrzsxwa", "vamuvkgd", "datacfguam", "spjvsyydjlhd",
- "datapjbblukgctv")))
- .withParameters(mapOf("ulojwumfjdymeq",
- new ParameterSpecification().withType(ParameterType.ARRAY).withDefaultValue("datavyeegx"),
- "nxemhqpzhnatw",
- new ParameterSpecification().withType(ParameterType.BOOL).withDefaultValue("datapfyxdjspn")))
- .withAnnotations(Arrays.asList("datamcvdjlwwefevtwll", "dataypmjc", "datay", "datafwgkzuhk"))
- .withFolder(new DatasetFolder().withName("jkckwbqwjyfmmk"))
- .withTableName("datamrslwknrd");
+ ZohoObjectDataset model = new ZohoObjectDataset().withDescription("b")
+ .withStructure("datavtuekbb")
+ .withSchema("dataqsm")
+ .withLinkedServiceName(new LinkedServiceReference().withReferenceName("sbeqieiuxhj")
+ .withParameters(
+ mapOf("lzyxvtajfjatoid", "datadalnjjhrgkjjpcpi", "gnpuelrnanbrpkoc", "dataekurdgcpzanaqve")))
+ .withParameters(mapOf("gijxmdboe",
+ new ParameterSpecification().withType(ParameterType.INT).withDefaultValue("datagegjtjltckiwxggf"), "u",
+ new ParameterSpecification().withType(ParameterType.FLOAT).withDefaultValue("dataxha")))
+ .withAnnotations(Arrays.asList("datanvzsodmokrqd", "datasgkq"))
+ .withFolder(new DatasetFolder().withName("otypcjxh"))
+ .withTableName("dataotmmxlmxejwyv");
model = BinaryData.fromObject(model).toObject(ZohoObjectDataset.class);
- Assertions.assertEquals("mbjern", model.description());
- Assertions.assertEquals("tkdeetnnef", model.linkedServiceName().referenceName());
- Assertions.assertEquals(ParameterType.ARRAY, model.parameters().get("ulojwumfjdymeq").type());
- Assertions.assertEquals("jkckwbqwjyfmmk", model.folder().name());
+ Assertions.assertEquals("b", model.description());
+ Assertions.assertEquals("sbeqieiuxhj", model.linkedServiceName().referenceName());
+ Assertions.assertEquals(ParameterType.INT, model.parameters().get("gijxmdboe").type());
+ Assertions.assertEquals("otypcjxh", model.folder().name());
}
// Use "Map.of" if available
diff --git a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoSourceTests.java b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoSourceTests.java
index ae55477d1350..b703cd0e4c89 100644
--- a/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoSourceTests.java
+++ b/sdk/datafactory/azure-resourcemanager-datafactory/src/test/java/com/azure/resourcemanager/datafactory/generated/ZohoSourceTests.java
@@ -11,19 +11,19 @@ public final class ZohoSourceTests {
@org.junit.jupiter.api.Test
public void testDeserialize() throws Exception {
ZohoSource model = BinaryData.fromString(
- "{\"type\":\"ZohoSource\",\"query\":\"databetzydtgpvnczf\",\"queryTimeout\":\"dataybjku\",\"additionalColumns\":\"dataajkyrhucbfkaqlp\",\"sourceRetryCount\":\"dataptero\",\"sourceRetryWait\":\"dataqaktao\",\"maxConcurrentConnections\":\"datagefobcqvzmyw\",\"disableMetricsCollection\":\"datayns\",\"\":{\"kklzabauvncln\":\"dataosqvojgol\",\"ikireetvjfizafd\":\"dataaoidjhoykgtyvrn\",\"csipfwlye\":\"datajhnuvndgrolgxa\",\"rzfppopwxxdgzhn\":\"dataajdpjmqteirrjjm\"}}")
+ "{\"type\":\"ZohoSource\",\"query\":\"dataarwtkrbscw\",\"queryTimeout\":\"datawvwmcrhyo\",\"additionalColumns\":\"datatplmy\",\"sourceRetryCount\":\"datahvyj\",\"sourceRetryWait\":\"dataerh\",\"maxConcurrentConnections\":\"datastiawywppq\",\"disableMetricsCollection\":\"datajxbdyczplmljcisx\",\"\":{\"mufdynhqlzanta\":\"dataftytp\"}}")
.toObject(ZohoSource.class);
}
@org.junit.jupiter.api.Test
public void testSerialize() throws Exception {
- ZohoSource model = new ZohoSource().withSourceRetryCount("dataptero")
- .withSourceRetryWait("dataqaktao")
- .withMaxConcurrentConnections("datagefobcqvzmyw")
- .withDisableMetricsCollection("datayns")
- .withQueryTimeout("dataybjku")
- .withAdditionalColumns("dataajkyrhucbfkaqlp")
- .withQuery("databetzydtgpvnczf");
+ ZohoSource model = new ZohoSource().withSourceRetryCount("datahvyj")
+ .withSourceRetryWait("dataerh")
+ .withMaxConcurrentConnections("datastiawywppq")
+ .withDisableMetricsCollection("datajxbdyczplmljcisx")
+ .withQueryTimeout("datawvwmcrhyo")
+ .withAdditionalColumns("datatplmy")
+ .withQuery("dataarwtkrbscw");
model = BinaryData.fromObject(model).toObject(ZohoSource.class);
}
}
diff --git a/sdk/datafactory/tests.mgmt.yml b/sdk/datafactory/tests.mgmt.yml
index 063ad3bf9600..cf0d1a934311 100644
--- a/sdk/datafactory/tests.mgmt.yml
+++ b/sdk/datafactory/tests.mgmt.yml
@@ -10,3 +10,6 @@ extends:
- name: azure-resourcemanager-datafactory
groupId: com.azure.resourcemanager
safeName: azureresourcemanagerdatafactory
+ # Only run tests on Windows to save cost.
+ MatrixFilters:
+ - pool=.*(win).*
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/CHANGELOG.md b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/CHANGELOG.md
index 4f189d7621be..20bc22df6448 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/CHANGELOG.md
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/CHANGELOG.md
@@ -1,6 +1,6 @@
# Release History
-## 1.0.0-beta.2 (Unreleased)
+## 1.0.0-beta.3 (Unreleased)
### Features Added
@@ -10,6 +10,380 @@
### Other Changes
+## 1.0.0-beta.2 (2024-12-16)
+
+- Azure Resource Manager Device Registry client library for Java. This package contains Microsoft Azure SDK for Device Registry Management SDK. Microsoft.DeviceRegistry Resource Provider management API. For documentation on how to use this package, please see [Azure Management Libraries for Java](https://aka.ms/azsdk/java/mgmt).
+
+### Breaking Changes
+
+#### `models.EventsObservabilityMode` was removed
+
+#### `models.OwnCertificate` was removed
+
+#### `models.UserAuthentication` was removed
+
+#### `models.UserAuthenticationMode` was removed
+
+#### `models.TransportAuthentication` was removed
+
+#### `implementation.models.PagedOperation` was removed
+
+#### `models.DataPointsObservabilityMode` was removed
+
+#### `models.Event` was modified
+
+* `eventNotifier()` was removed
+* `withObservabilityMode(models.EventsObservabilityMode)` was removed
+* `capabilityId()` was removed
+* `withCapabilityId(java.lang.String)` was removed
+* `eventConfiguration()` was removed
+* `name()` was removed
+* `models.EventsObservabilityMode observabilityMode()` -> `models.EventObservabilityMode observabilityMode()`
+
+#### `models.AssetProperties` was modified
+
+* `defaultDataPointsConfiguration()` was removed
+* `withAssetType(java.lang.String)` was removed
+* `assetType()` was removed
+* `java.lang.Integer version()` -> `java.lang.Long version()`
+* `withDefaultDataPointsConfiguration(java.lang.String)` was removed
+* `dataPoints()` was removed
+* `withAssetEndpointProfileUri(java.lang.String)` was removed
+* `assetEndpointProfileUri()` was removed
+* `withDataPoints(java.util.List)` was removed
+
+#### `models.X509Credentials` was modified
+
+* `withCertificateReference(java.lang.String)` was removed
+* `certificateReference()` was removed
+
+#### `models.AssetStatus` was modified
+
+* `java.lang.Integer version()` -> `java.lang.Long version()`
+
+#### `models.OperationStatusResult` was modified
+
+* `java.lang.Integer percentComplete()` -> `java.lang.Double percentComplete()`
+
+#### `DeviceRegistryManager` was modified
+
+* `fluent.DeviceRegistryClient serviceClient()` -> `fluent.DeviceRegistryManagementClient serviceClient()`
+
+#### `models.AssetEndpointProfileProperties` was modified
+
+* `transportAuthentication()` was removed
+* `userAuthentication()` was removed
+* `withTransportAuthentication(models.TransportAuthentication)` was removed
+* `withUserAuthentication(models.UserAuthentication)` was removed
+
+#### `models.AssetUpdateProperties` was modified
+
+* `withDefaultDataPointsConfiguration(java.lang.String)` was removed
+* `assetType()` was removed
+* `dataPoints()` was removed
+* `withAssetType(java.lang.String)` was removed
+* `defaultDataPointsConfiguration()` was removed
+* `withDataPoints(java.util.List)` was removed
+
+#### `models.UsernamePasswordCredentials` was modified
+
+* `usernameReference()` was removed
+* `withPasswordReference(java.lang.String)` was removed
+* `withUsernameReference(java.lang.String)` was removed
+* `passwordReference()` was removed
+
+#### `models.AssetEndpointProfileUpdateProperties` was modified
+
+* `userAuthentication()` was removed
+* `withUserAuthentication(models.UserAuthentication)` was removed
+* `withTransportAuthentication(models.TransportAuthentication)` was removed
+* `transportAuthentication()` was removed
+
+#### `models.DataPoint` was modified
+
+* `withCapabilityId(java.lang.String)` was removed
+* `dataSource()` was removed
+* `capabilityId()` was removed
+* `dataPointConfiguration()` was removed
+* `withObservabilityMode(models.DataPointsObservabilityMode)` was removed
+* `models.DataPointsObservabilityMode observabilityMode()` -> `models.DataPointObservabilityMode observabilityMode()`
+* `name()` was removed
+
+### Features Added
+
+* `models.AssetEndpointProfileStatus` was added
+
+* `models.DiscoveredEvent` was added
+
+* `models.Dataset` was added
+
+* `models.Schema` was added
+
+* `models.DataPointObservabilityMode` was added
+
+* `models.Authentication` was added
+
+* `models.DiscoveredAsset$Definition` was added
+
+* `models.SchemaProperties` was added
+
+* `models.DiscoveredAsset$DefinitionStages` was added
+
+* `models.DiscoveredAssets` was added
+
+* `implementation.models.SchemaListResult` was added
+
+* `models.SystemAssignedServiceIdentityType` was added
+
+* `models.SchemaRegistry$Definition` was added
+
+* `models.AuthenticationMethod` was added
+
+* `implementation.models.DiscoveredAssetEndpointProfileListResult` was added
+
+* `models.DataPointBase` was added
+
+* `models.EventBase` was added
+
+* `implementation.models.OperationListResult` was added
+
+* `models.DiscoveredAssetEndpointProfile$Definition` was added
+
+* `models.SchemaVersion` was added
+
+* `models.DiscoveredDataPoint` was added
+
+* `models.Schema$DefinitionStages` was added
+
+* `models.Format` was added
+
+* `models.EventObservabilityMode` was added
+
+* `models.TopicRetainType` was added
+
+* `models.SchemaRegistryUpdateProperties` was added
+
+* `models.DiscoveredAssetEndpointProfile` was added
+
+* `models.SystemAssignedServiceIdentity` was added
+
+* `models.SchemaRegistryProperties` was added
+
+* `models.DiscoveredAssetEndpointProfile$DefinitionStages` was added
+
+* `models.DiscoveredAssetEndpointProfiles` was added
+
+* `models.SchemaVersion$DefinitionStages` was added
+
+* `models.SchemaVersionProperties` was added
+
+* `models.AssetStatusDataset` was added
+
+* `implementation.models.SchemaVersionListResult` was added
+
+* `models.DiscoveredAssetProperties` was added
+
+* `models.DiscoveredAssetEndpointProfile$UpdateStages` was added
+
+* `models.DiscoveredAssetEndpointProfileProperties` was added
+
+* `models.AssetEndpointProfileStatusError` was added
+
+* `models.SchemaRegistry$UpdateStages` was added
+
+* `models.DiscoveredAssetEndpointProfileUpdateProperties` was added
+
+* `models.BillingContainer` was added
+
+* `models.AssetStatusEvent` was added
+
+* `models.DiscoveredAsset$Update` was added
+
+* `models.BillingContainerProperties` was added
+
+* `implementation.models.SchemaRegistryListResult` was added
+
+* `models.DiscoveredAssetUpdateProperties` was added
+
+* `models.SchemaRegistry$Update` was added
+
+* `models.SchemaType` was added
+
+* `models.SchemaRegistries` was added
+
+* `models.SchemaRegistryUpdate` was added
+
+* `models.DiscoveredAsset$UpdateStages` was added
+
+* `models.Schema$Definition` was added
+
+* `models.SchemaVersion$Definition` was added
+
+* `models.Schemas` was added
+
+* `models.BillingContainers` was added
+
+* `models.DiscoveredAssetEndpointProfile$Update` was added
+
+* `models.SchemaRegistry$DefinitionStages` was added
+
+* `models.SchemaVersions` was added
+
+* `models.MessageSchemaReference` was added
+
+* `models.DiscoveredAssetUpdate` was added
+
+* `models.DiscoveredAssetEndpointProfileUpdate` was added
+
+* `models.SchemaRegistry` was added
+
+* `implementation.models.BillingContainerListResult` was added
+
+* `implementation.models.DiscoveredAssetListResult` was added
+
+* `models.DiscoveredDataset` was added
+
+* `models.Topic` was added
+
+* `models.DiscoveredAsset` was added
+
+#### `models.Event` was modified
+
+* `toJson(com.azure.json.JsonWriter)` was added
+* `withEventConfiguration(java.lang.String)` was added
+* `withTopic(models.Topic)` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `withName(java.lang.String)` was added
+* `withObservabilityMode(models.EventObservabilityMode)` was added
+* `withEventNotifier(java.lang.String)` was added
+
+#### `models.AssetProperties` was modified
+
+* `defaultTopic()` was added
+* `withDefaultTopic(models.Topic)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+* `discoveredAssetRefs()` was added
+* `withDiscoveredAssetRefs(java.util.List)` was added
+* `assetEndpointProfileRef()` was added
+* `withDefaultDatasetsConfiguration(java.lang.String)` was added
+* `datasets()` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `withDatasets(java.util.List)` was added
+* `withAssetEndpointProfileRef(java.lang.String)` was added
+* `defaultDatasetsConfiguration()` was added
+
+#### `models.X509Credentials` was modified
+
+* `certificateSecretName()` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `withCertificateSecretName(java.lang.String)` was added
+
+#### `implementation.models.AssetListResult` was modified
+
+* `fromJson(com.azure.json.JsonReader)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+
+#### `models.AssetStatus` was modified
+
+* `fromJson(com.azure.json.JsonReader)` was added
+* `events()` was added
+* `datasets()` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+
+#### `models.OperationStatusResult` was modified
+
+* `resourceId()` was added
+
+#### `models.AssetStatusError` was modified
+
+* `toJson(com.azure.json.JsonWriter)` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+
+#### `models.AssetUpdate` was modified
+
+* `fromJson(com.azure.json.JsonReader)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+
+#### `DeviceRegistryManager` was modified
+
+* `discoveredAssets()` was added
+* `schemaRegistries()` was added
+* `billingContainers()` was added
+* `discoveredAssetEndpointProfiles()` was added
+* `schemas()` was added
+* `schemaVersions()` was added
+
+#### `models.AssetEndpointProfileProperties` was modified
+
+* `discoveredAssetEndpointProfileRef()` was added
+* `withEndpointProfileType(java.lang.String)` was added
+* `endpointProfileType()` was added
+* `status()` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `withDiscoveredAssetEndpointProfileRef(java.lang.String)` was added
+* `withAuthentication(models.Authentication)` was added
+* `authentication()` was added
+
+#### `models.AssetUpdateProperties` was modified
+
+* `defaultDatasetsConfiguration()` was added
+* `withDefaultTopic(models.Topic)` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `defaultTopic()` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+* `datasets()` was added
+* `withDefaultDatasetsConfiguration(java.lang.String)` was added
+* `withDatasets(java.util.List)` was added
+
+#### `models.UsernamePasswordCredentials` was modified
+
+* `withUsernameSecretName(java.lang.String)` was added
+* `passwordSecretName()` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `usernameSecretName()` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+* `withPasswordSecretName(java.lang.String)` was added
+
+#### `models.ExtendedLocation` was modified
+
+* `fromJson(com.azure.json.JsonReader)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+
+#### `models.AssetEndpointProfileUpdateProperties` was modified
+
+* `endpointProfileType()` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+* `withAuthentication(models.Authentication)` was added
+* `authentication()` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `withEndpointProfileType(java.lang.String)` was added
+
+#### `models.AssetEndpointProfileUpdate` was modified
+
+* `fromJson(com.azure.json.JsonReader)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+
+#### `models.OperationDisplay` was modified
+
+* `fromJson(com.azure.json.JsonReader)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+
+#### `models.DataPoint` was modified
+
+* `withDataPointConfiguration(java.lang.String)` was added
+* `withObservabilityMode(models.DataPointObservabilityMode)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+* `fromJson(com.azure.json.JsonReader)` was added
+* `withName(java.lang.String)` was added
+* `withDataSource(java.lang.String)` was added
+
+#### `implementation.models.AssetEndpointProfileListResult` was modified
+
+* `fromJson(com.azure.json.JsonReader)` was added
+* `toJson(com.azure.json.JsonWriter)` was added
+
## 1.0.0-beta.1 (2024-04-26)
- Azure Resource Manager Device Registry client library for Java. This package contains Microsoft Azure SDK for Device Registry Management SDK. Microsoft.DeviceRegistry Resource Provider management API. Package tag package-preview-2023-11. For documentation on how to use this package, please see [Azure Management Libraries for Java](https://aka.ms/azsdk/java/mgmt).
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/README.md b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/README.md
index 92dc385be4a9..de2739da6ed8 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/README.md
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/README.md
@@ -32,7 +32,7 @@ Various documentation is available to help you get started
com.azure.resourcemanager
azure-resourcemanager-deviceregistry
- 1.0.0-beta.1
+ 1.0.0-beta.2
```
[//]: # ({x-version-update-end})
@@ -45,15 +45,11 @@ Azure Management Libraries require a `TokenCredential` implementation for authen
### Authentication
-By default, Microsoft Entra ID token authentication depends on correct configuration of the following environment variables.
+Microsoft Entra ID token authentication relies on the [credential class][azure_identity_credentials] from [Azure Identity][azure_identity] package.
-- `AZURE_CLIENT_ID` for Azure client ID.
-- `AZURE_TENANT_ID` for Azure tenant ID.
-- `AZURE_CLIENT_SECRET` or `AZURE_CLIENT_CERTIFICATE_PATH` for client secret or client certificate.
+Azure subscription ID can be configured via `AZURE_SUBSCRIPTION_ID` environment variable.
-In addition, Azure subscription ID can be configured via `AZURE_SUBSCRIPTION_ID` environment variable.
-
-With above configuration, `azure` client can be authenticated using the following code:
+Assuming the use of the `DefaultAzureCredential` credential class, the client can be authenticated using the following code:
```java
AzureProfile profile = new AzureProfile(AzureEnvironment.AZURE);
@@ -97,6 +93,7 @@ This project has adopted the [Microsoft Open Source Code of Conduct][coc]. For m
[jdk]: https://learn.microsoft.com/azure/developer/java/fundamentals/
[azure_subscription]: https://azure.microsoft.com/free/
[azure_identity]: https://github.com/Azure/azure-sdk-for-java/blob/main/sdk/identity/azure-identity
+[azure_identity_credentials]: https://github.com/Azure/azure-sdk-for-java/tree/main/sdk/identity/azure-identity#credentials
[azure_core_http_netty]: https://github.com/Azure/azure-sdk-for-java/blob/main/sdk/core/azure-core-http-netty
[authenticate]: https://github.com/Azure/azure-sdk-for-java/blob/main/sdk/resourcemanager/docs/AUTH.md
[design]: https://github.com/Azure/azure-sdk-for-java/blob/main/sdk/resourcemanager/docs/DESIGN.md
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/SAMPLE.md b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/SAMPLE.md
index 39981bf8d413..79279e2d46d7 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/SAMPLE.md
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/SAMPLE.md
@@ -19,6 +19,29 @@
- [ListByResourceGroup](#assets_listbyresourcegroup)
- [Update](#assets_update)
+## BillingContainers
+
+- [Get](#billingcontainers_get)
+- [List](#billingcontainers_list)
+
+## DiscoveredAssetEndpointProfiles
+
+- [CreateOrReplace](#discoveredassetendpointprofiles_createorreplace)
+- [Delete](#discoveredassetendpointprofiles_delete)
+- [GetByResourceGroup](#discoveredassetendpointprofiles_getbyresourcegroup)
+- [List](#discoveredassetendpointprofiles_list)
+- [ListByResourceGroup](#discoveredassetendpointprofiles_listbyresourcegroup)
+- [Update](#discoveredassetendpointprofiles_update)
+
+## DiscoveredAssets
+
+- [CreateOrReplace](#discoveredassets_createorreplace)
+- [Delete](#discoveredassets_delete)
+- [GetByResourceGroup](#discoveredassets_getbyresourcegroup)
+- [List](#discoveredassets_list)
+- [ListByResourceGroup](#discoveredassets_listbyresourcegroup)
+- [Update](#discoveredassets_update)
+
## OperationStatus
- [Get](#operationstatus_get)
@@ -26,13 +49,36 @@
## Operations
- [List](#operations_list)
+
+## SchemaRegistries
+
+- [CreateOrReplace](#schemaregistries_createorreplace)
+- [Delete](#schemaregistries_delete)
+- [GetByResourceGroup](#schemaregistries_getbyresourcegroup)
+- [List](#schemaregistries_list)
+- [ListByResourceGroup](#schemaregistries_listbyresourcegroup)
+- [Update](#schemaregistries_update)
+
+## SchemaVersions
+
+- [CreateOrReplace](#schemaversions_createorreplace)
+- [Delete](#schemaversions_delete)
+- [Get](#schemaversions_get)
+- [ListBySchema](#schemaversions_listbyschema)
+
+## Schemas
+
+- [CreateOrReplace](#schemas_createorreplace)
+- [Delete](#schemas_delete)
+- [Get](#schemas_get)
+- [ListBySchemaRegistry](#schemas_listbyschemaregistry)
### AssetEndpointProfiles_CreateOrReplace
```java
import com.azure.resourcemanager.deviceregistry.models.AssetEndpointProfileProperties;
+import com.azure.resourcemanager.deviceregistry.models.Authentication;
+import com.azure.resourcemanager.deviceregistry.models.AuthenticationMethod;
import com.azure.resourcemanager.deviceregistry.models.ExtendedLocation;
-import com.azure.resourcemanager.deviceregistry.models.UserAuthentication;
-import com.azure.resourcemanager.deviceregistry.models.UserAuthenticationMode;
import java.util.HashMap;
import java.util.Map;
@@ -41,9 +87,33 @@ import java.util.Map;
*/
public final class AssetEndpointProfilesCreateOrReplaceSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Create_AssetEndpointProfile.
- * json
+ * x-ms-original-file: 2024-09-01-preview/Create_AssetEndpointProfile_With_DiscoveredAepRef.json
+ */
+ /**
+ * Sample code: Create_AssetEndpointProfile_With_DiscoveredAepRef.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void createAssetEndpointProfileWithDiscoveredAepRef(
+ com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.assetEndpointProfiles()
+ .define("my-assetendpointprofile")
+ .withRegion("West Europe")
+ .withExistingResourceGroup("myResourceGroup")
+ .withExtendedLocation(new ExtendedLocation().withType("CustomLocation")
+ .withName(
+ "/subscriptions/00000000-0000-0000-0000-000000000000/resourcegroups/myResourceGroup/providers/microsoft.extendedlocation/customlocations/location1"))
+ .withTags(mapOf("site", "building-1"))
+ .withProperties(
+ new AssetEndpointProfileProperties().withTargetAddress("https://www.example.com/myTargetAddress")
+ .withEndpointProfileType("myEndpointProfileType")
+ .withAuthentication(new Authentication().withMethod(AuthenticationMethod.ANONYMOUS))
+ .withDiscoveredAssetEndpointProfileRef("discoveredAssetEndpointProfile1"))
+ .create();
+ }
+
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_AssetEndpointProfile.json
*/
/**
* Sample code: Create_AssetEndpointProfile.
@@ -62,7 +132,8 @@ public final class AssetEndpointProfilesCreateOrReplaceSamples {
.withTags(mapOf("site", "building-1"))
.withProperties(
new AssetEndpointProfileProperties().withTargetAddress("https://www.example.com/myTargetAddress")
- .withUserAuthentication(new UserAuthentication().withMode(UserAuthenticationMode.ANONYMOUS)))
+ .withEndpointProfileType("myEndpointProfileType")
+ .withAuthentication(new Authentication().withMethod(AuthenticationMethod.ANONYMOUS)))
.create();
}
@@ -88,9 +159,7 @@ public final class AssetEndpointProfilesCreateOrReplaceSamples {
*/
public final class AssetEndpointProfilesDeleteSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Delete_AssetEndpointProfile.
- * json
+ * x-ms-original-file: 2024-09-01-preview/Delete_AssetEndpointProfile.json
*/
/**
* Sample code: Delete_AssetEndpointProfile.
@@ -113,8 +182,7 @@ public final class AssetEndpointProfilesDeleteSamples {
*/
public final class AssetEndpointProfilesGetByResourceGroupSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Get_AssetEndpointProfile.json
+ * x-ms-original-file: 2024-09-01-preview/Get_AssetEndpointProfile.json
*/
/**
* Sample code: Get_AssetEndpointProfile.
@@ -126,6 +194,21 @@ public final class AssetEndpointProfilesGetByResourceGroupSamples {
.getByResourceGroupWithResponse("myResourceGroup", "my-assetendpointprofile",
com.azure.core.util.Context.NONE);
}
+
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_AssetEndpointProfile_With_SyncStatus.json
+ */
+ /**
+ * Sample code: Get_AssetEndpointProfile_With_SyncStatus.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ getAssetEndpointProfileWithSyncStatus(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.assetEndpointProfiles()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-assetendpointprofile",
+ com.azure.core.util.Context.NONE);
+ }
}
```
@@ -137,8 +220,7 @@ public final class AssetEndpointProfilesGetByResourceGroupSamples {
*/
public final class AssetEndpointProfilesListSamples {
/*
- * x-ms-original-file: specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/
- * List_AssetEndpointProfiles_Subscription.json
+ * x-ms-original-file: 2024-09-01-preview/List_AssetEndpointProfiles_Subscription.json
*/
/**
* Sample code: List_AssetEndpointProfiles_Subscription.
@@ -160,8 +242,7 @@ public final class AssetEndpointProfilesListSamples {
*/
public final class AssetEndpointProfilesListByResourceGroupSamples {
/*
- * x-ms-original-file: specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/
- * List_AssetEndpointProfiles_ResourceGroup.json
+ * x-ms-original-file: 2024-09-01-preview/List_AssetEndpointProfiles_ResourceGroup.json
*/
/**
* Sample code: List_AssetEndpointProfiles_ResourceGroup.
@@ -186,9 +267,7 @@ import com.azure.resourcemanager.deviceregistry.models.AssetEndpointProfileUpdat
*/
public final class AssetEndpointProfilesUpdateSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Update_AssetEndpointProfile.
- * json
+ * x-ms-original-file: 2024-09-01-preview/Update_AssetEndpointProfile.json
*/
/**
* Sample code: Update_AssetEndpointProfile.
@@ -214,10 +293,13 @@ public final class AssetEndpointProfilesUpdateSamples {
```java
import com.azure.resourcemanager.deviceregistry.models.AssetProperties;
import com.azure.resourcemanager.deviceregistry.models.DataPoint;
-import com.azure.resourcemanager.deviceregistry.models.DataPointsObservabilityMode;
+import com.azure.resourcemanager.deviceregistry.models.DataPointObservabilityMode;
+import com.azure.resourcemanager.deviceregistry.models.Dataset;
import com.azure.resourcemanager.deviceregistry.models.Event;
-import com.azure.resourcemanager.deviceregistry.models.EventsObservabilityMode;
+import com.azure.resourcemanager.deviceregistry.models.EventObservabilityMode;
import com.azure.resourcemanager.deviceregistry.models.ExtendedLocation;
+import com.azure.resourcemanager.deviceregistry.models.Topic;
+import com.azure.resourcemanager.deviceregistry.models.TopicRetainType;
import java.util.Arrays;
import java.util.HashMap;
import java.util.Map;
@@ -227,8 +309,205 @@ import java.util.Map;
*/
public final class AssetsCreateOrReplaceSamples {
/*
- * x-ms-original-file: specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/
- * Create_Asset_Without_DisplayName.json
+ * x-ms-original-file: 2024-09-01-preview/Create_Asset_With_DiscoveredAssetRef.json
+ */
+ /**
+ * Sample code: Create_Asset_With_DiscoveredAssetRefs.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ createAssetWithDiscoveredAssetRefs(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.assets()
+ .define("my-asset")
+ .withRegion("West Europe")
+ .withExistingResourceGroup("myResourceGroup")
+ .withExtendedLocation(new ExtendedLocation().withType("CustomLocation")
+ .withName(
+ "/subscriptions/00000000-0000-0000-0000-000000000000/resourcegroups/myResourceGroup/providers/microsoft.extendedlocation/customlocations/location1"))
+ .withTags(mapOf("site", "building-1"))
+ .withProperties(new AssetProperties().withEnabled(true)
+ .withExternalAssetId("8ZBA6LRHU0A458969")
+ .withDisplayName("AssetDisplayName")
+ .withDescription("This is a sample Asset")
+ .withAssetEndpointProfileRef("myAssetEndpointProfile")
+ .withManufacturer("Contoso")
+ .withManufacturerUri("https://www.contoso.com/manufacturerUri")
+ .withModel("ContosoModel")
+ .withProductCode("fakeTokenPlaceholder")
+ .withHardwareRevision("1.0")
+ .withSoftwareRevision("2.0")
+ .withDocumentationUri("https://www.example.com/manual")
+ .withSerialNumber("64-103816-519918-8")
+ .withDiscoveredAssetRefs(Arrays.asList("discoveredAsset1", "discoveredAsset2"))
+ .withDefaultDatasetsConfiguration(
+ "{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultEventsConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultTopic(new Topic().withPath("/path/defaultTopic").withRetain(TopicRetainType.KEEP))
+ .withDatasets(Arrays.asList(new Dataset().withName("dataset1")
+ .withDatasetConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withTopic(new Topic().withPath("/path/dataset1").withRetain(TopicRetainType.KEEP))
+ .withDataPoints(Arrays.asList(
+ new DataPoint().withName("dataPoint1")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt1")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":8,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(DataPointObservabilityMode.COUNTER),
+ new DataPoint().withName("dataPoint2")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt2")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":4,\"samplingInterval\":4,\"queueSize\":7}")
+ .withObservabilityMode(DataPointObservabilityMode.NONE)))))
+ .withEvents(
+ Arrays
+ .asList(
+ new Event().withName("event1")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt3")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":1,\"queueSize\":8}")
+ .withTopic(new Topic().withPath("/path/event1").withRetain(TopicRetainType.KEEP))
+ .withObservabilityMode(EventObservabilityMode.NONE),
+ new Event().withName("event2")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt4")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(EventObservabilityMode.LOG))))
+ .create();
+ }
+
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_Asset_Without_ExternalAssetId.json
+ */
+ /**
+ * Sample code: Create_Asset_Without_ExternalAssetId.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ createAssetWithoutExternalAssetId(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.assets()
+ .define("my-asset")
+ .withRegion("West Europe")
+ .withExistingResourceGroup("myResourceGroup")
+ .withExtendedLocation(new ExtendedLocation().withType("CustomLocation")
+ .withName(
+ "/subscriptions/00000000-0000-0000-0000-000000000000/resourcegroups/myResourceGroup/providers/microsoft.extendedlocation/customlocations/location1"))
+ .withTags(mapOf("site", "building-1"))
+ .withProperties(new AssetProperties().withEnabled(true)
+ .withDisplayName("AssetDisplayName")
+ .withDescription("This is a sample Asset")
+ .withAssetEndpointProfileRef("myAssetEndpointProfile")
+ .withManufacturer("Contoso")
+ .withManufacturerUri("https://www.contoso.com/manufacturerUri")
+ .withModel("ContosoModel")
+ .withProductCode("fakeTokenPlaceholder")
+ .withHardwareRevision("1.0")
+ .withSoftwareRevision("2.0")
+ .withDocumentationUri("https://www.example.com/manual")
+ .withSerialNumber("64-103816-519918-8")
+ .withDefaultDatasetsConfiguration(
+ "{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultEventsConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultTopic(new Topic().withPath("/path/defaultTopic").withRetain(TopicRetainType.KEEP))
+ .withDatasets(Arrays.asList(new Dataset().withName("dataset1")
+ .withDatasetConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withTopic(new Topic().withPath("/path/dataset1").withRetain(TopicRetainType.KEEP))
+ .withDataPoints(Arrays.asList(
+ new DataPoint().withName("dataPoint1")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt1")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":8,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(DataPointObservabilityMode.COUNTER),
+ new DataPoint().withName("dataPoint2")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt2")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":4,\"samplingInterval\":4,\"queueSize\":7}")
+ .withObservabilityMode(DataPointObservabilityMode.NONE)))))
+ .withEvents(
+ Arrays
+ .asList(
+ new Event().withName("event1")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt3")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":1,\"queueSize\":8}")
+ .withTopic(new Topic().withPath("/path/event1").withRetain(TopicRetainType.KEEP))
+ .withObservabilityMode(EventObservabilityMode.NONE),
+ new Event().withName("event2")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt4")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(EventObservabilityMode.LOG))))
+ .create();
+ }
+
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_Asset_With_ExternalAssetId.json
+ */
+ /**
+ * Sample code: Create_Asset_With_ExternalAssetId.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ createAssetWithExternalAssetId(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.assets()
+ .define("my-asset")
+ .withRegion("West Europe")
+ .withExistingResourceGroup("myResourceGroup")
+ .withExtendedLocation(new ExtendedLocation().withType("CustomLocation")
+ .withName(
+ "/subscriptions/00000000-0000-0000-0000-000000000000/resourcegroups/myResourceGroup/providers/microsoft.extendedlocation/customlocations/location1"))
+ .withTags(mapOf("site", "building-1"))
+ .withProperties(new AssetProperties().withEnabled(true)
+ .withExternalAssetId("8ZBA6LRHU0A458969")
+ .withDisplayName("AssetDisplayName")
+ .withDescription("This is a sample Asset")
+ .withAssetEndpointProfileRef("myAssetEndpointProfile")
+ .withManufacturer("Contoso")
+ .withManufacturerUri("https://www.contoso.com/manufacturerUri")
+ .withModel("ContosoModel")
+ .withProductCode("fakeTokenPlaceholder")
+ .withHardwareRevision("1.0")
+ .withSoftwareRevision("2.0")
+ .withDocumentationUri("https://www.example.com/manual")
+ .withSerialNumber("64-103816-519918-8")
+ .withDefaultDatasetsConfiguration(
+ "{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultEventsConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultTopic(new Topic().withPath("/path/defaultTopic").withRetain(TopicRetainType.KEEP))
+ .withDatasets(Arrays.asList(new Dataset().withName("dataset1")
+ .withDatasetConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withTopic(new Topic().withPath("/path/dataset1").withRetain(TopicRetainType.KEEP))
+ .withDataPoints(Arrays.asList(
+ new DataPoint().withName("dataPoint1")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt1")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":8,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(DataPointObservabilityMode.COUNTER),
+ new DataPoint().withName("dataPoint2")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt2")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":4,\"samplingInterval\":4,\"queueSize\":7}")
+ .withObservabilityMode(DataPointObservabilityMode.NONE)))))
+ .withEvents(
+ Arrays
+ .asList(
+ new Event().withName("event1")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt3")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":1,\"queueSize\":8}")
+ .withTopic(new Topic().withPath("/path/event1").withRetain(TopicRetainType.KEEP))
+ .withObservabilityMode(EventObservabilityMode.NONE),
+ new Event().withName("event2")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt4")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(EventObservabilityMode.LOG))))
+ .create();
+ }
+
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_Asset_Without_DisplayName.json
*/
/**
* Sample code: Create_Asset_Without_DisplayName.
@@ -245,11 +524,10 @@ public final class AssetsCreateOrReplaceSamples {
.withName(
"/subscriptions/00000000-0000-0000-0000-000000000000/resourcegroups/myResourceGroup/providers/microsoft.extendedlocation/customlocations/location1"))
.withTags(mapOf("site", "building-1"))
- .withProperties(new AssetProperties().withAssetType("MyAssetType")
- .withEnabled(true)
+ .withProperties(new AssetProperties().withEnabled(true)
.withExternalAssetId("8ZBA6LRHU0A458969")
.withDescription("This is a sample Asset")
- .withAssetEndpointProfileUri("https://www.example.com/myAssetEndpointProfile")
+ .withAssetEndpointProfileRef("myAssetEndpointProfile")
.withManufacturer("Contoso")
.withManufacturerUri("https://www.contoso.com/manufacturerUri")
.withModel("ContosoModel")
@@ -258,29 +536,38 @@ public final class AssetsCreateOrReplaceSamples {
.withSoftwareRevision("2.0")
.withDocumentationUri("https://www.example.com/manual")
.withSerialNumber("64-103816-519918-8")
- .withDefaultDataPointsConfiguration(
+ .withDefaultDatasetsConfiguration(
"{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
.withDefaultEventsConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
- .withDataPoints(Arrays.asList(
- new DataPoint().withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt1")
- .withCapabilityId("dtmi:com:example:Thermostat:__temperature;1")
- .withObservabilityMode(DataPointsObservabilityMode.COUNTER)
- .withDataPointConfiguration(
- "{\"publishingInterval\":8,\"samplingInterval\":8,\"queueSize\":4}"),
- new DataPoint().withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt2")
- .withCapabilityId("dtmi:com:example:Thermostat:__pressure;1")
- .withObservabilityMode(DataPointsObservabilityMode.NONE)
- .withDataPointConfiguration(
- "{\"publishingInterval\":4,\"samplingInterval\":4,\"queueSize\":7}")))
- .withEvents(Arrays.asList(
- new Event().withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt3")
- .withCapabilityId("dtmi:com:example:Thermostat:__temperature;1")
- .withObservabilityMode(EventsObservabilityMode.NONE)
- .withEventConfiguration("{\"publishingInterval\":7,\"samplingInterval\":1,\"queueSize\":8}"),
- new Event().withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt4")
- .withCapabilityId("dtmi:com:example:Thermostat:__pressure;1")
- .withObservabilityMode(EventsObservabilityMode.LOG)
- .withEventConfiguration("{\"publishingInterval\":7,\"samplingInterval\":8,\"queueSize\":4}"))))
+ .withDefaultTopic(new Topic().withPath("/path/defaultTopic").withRetain(TopicRetainType.KEEP))
+ .withDatasets(Arrays.asList(new Dataset().withName("dataset1")
+ .withDatasetConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withTopic(new Topic().withPath("/path/dataset1").withRetain(TopicRetainType.KEEP))
+ .withDataPoints(Arrays.asList(
+ new DataPoint().withName("dataPoint1")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt1")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":8,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(DataPointObservabilityMode.COUNTER),
+ new DataPoint().withName("dataPoint2")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt2")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":4,\"samplingInterval\":4,\"queueSize\":7}")
+ .withObservabilityMode(DataPointObservabilityMode.NONE)))))
+ .withEvents(
+ Arrays
+ .asList(
+ new Event().withName("event1")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt3")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":1,\"queueSize\":8}")
+ .withTopic(new Topic().withPath("/path/event1").withRetain(TopicRetainType.KEEP))
+ .withObservabilityMode(EventObservabilityMode.NONE),
+ new Event().withName("event2")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt4")
+ .withEventConfiguration(
+ "{\"publishingInterval\":7,\"samplingInterval\":8,\"queueSize\":4}")
+ .withObservabilityMode(EventObservabilityMode.LOG))))
.create();
}
@@ -306,8 +593,7 @@ public final class AssetsCreateOrReplaceSamples {
*/
public final class AssetsDeleteSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Delete_Asset.json
+ * x-ms-original-file: 2024-09-01-preview/Delete_Asset.json
*/
/**
* Sample code: Delete_Asset.
@@ -328,8 +614,20 @@ public final class AssetsDeleteSamples {
*/
public final class AssetsGetByResourceGroupSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Get_Asset.json
+ * x-ms-original-file: 2024-09-01-preview/Get_Asset_With_SyncStatus.json
+ */
+ /**
+ * Sample code: Get_Asset_With_SyncStatus.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void getAssetWithSyncStatus(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.assets()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-asset", com.azure.core.util.Context.NONE);
+ }
+
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_Asset.json
*/
/**
* Sample code: Get_Asset.
@@ -351,8 +649,7 @@ public final class AssetsGetByResourceGroupSamples {
*/
public final class AssetsListSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/List_Assets_Subscription.json
+ * x-ms-original-file: 2024-09-01-preview/List_Assets_Subscription.json
*/
/**
* Sample code: List_Assets_Subscription.
@@ -373,8 +670,7 @@ public final class AssetsListSamples {
*/
public final class AssetsListByResourceGroupSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/List_Assets_ResourceGroup.json
+ * x-ms-original-file: 2024-09-01-preview/List_Assets_ResourceGroup.json
*/
/**
* Sample code: List_Assets_ResourceGroup.
@@ -398,8 +694,7 @@ import com.azure.resourcemanager.deviceregistry.models.AssetUpdateProperties;
*/
public final class AssetsUpdateSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Update_Asset.json
+ * x-ms-original-file: 2024-09-01-preview/Update_Asset.json
*/
/**
* Sample code: Update_Asset.
@@ -417,47 +712,877 @@ public final class AssetsUpdateSamples {
}
```
-### OperationStatus_Get
+### BillingContainers_Get
```java
/**
- * Samples for OperationStatus Get.
+ * Samples for BillingContainers Get.
*/
-public final class OperationStatusGetSamples {
+public final class BillingContainersGetSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/Get_OperationStatus.json
+ * x-ms-original-file: 2024-09-01-preview/Get_BillingContainer.json
*/
/**
- * Sample code: Get_OperationStatus.
+ * Sample code: Get_BillingContainer.
*
* @param manager Entry point to DeviceRegistryManager.
*/
- public static void getOperationStatus(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
- manager.operationStatus()
- .getWithResponse("testLocation", "xxxxxxxx-xxxx-xxxx-xxxx-xxxxxxxxxxxx", com.azure.core.util.Context.NONE);
+ public static void getBillingContainer(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.billingContainers().getWithResponse("my-billingContainer", com.azure.core.util.Context.NONE);
}
}
```
-### Operations_List
+### BillingContainers_List
```java
/**
- * Samples for Operations List.
+ * Samples for BillingContainers List.
*/
-public final class OperationsListSamples {
+public final class BillingContainersListSamples {
/*
- * x-ms-original-file:
- * specification/deviceregistry/DeviceRegistry.Management/examples/2023-11-01-preview/List_Operations.json
+ * x-ms-original-file: 2024-09-01-preview/List_BillingContainers_Subscription.json
*/
/**
- * Sample code: List_Operations.
+ * Sample code: List_BillingContainers_Subscription.
*
* @param manager Entry point to DeviceRegistryManager.
*/
- public static void listOperations(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
- manager.operations().list(com.azure.core.util.Context.NONE);
+ public static void
+ listBillingContainersSubscription(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.billingContainers().list(com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssetEndpointProfiles_CreateOrReplace
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.AuthenticationMethod;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileProperties;
+import com.azure.resourcemanager.deviceregistry.models.ExtendedLocation;
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Samples for DiscoveredAssetEndpointProfiles CreateOrReplace.
+ */
+public final class DiscoveredAssetEndpointProfilesCreateOrReplaceSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_DiscoveredAssetEndpointProfile.json
+ */
+ /**
+ * Sample code: Create_DiscoveredAssetEndpointProfile.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ createDiscoveredAssetEndpointProfile(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssetEndpointProfiles()
+ .define("my-discoveredassetendpointprofile")
+ .withRegion("West Europe")
+ .withExistingResourceGroup("myResourceGroup")
+ .withExtendedLocation(new ExtendedLocation().withType("CustomLocation")
+ .withName(
+ "/subscriptions/00000000-0000-0000-0000-000000000000/resourcegroups/myResourceGroup/providers/microsoft.extendedlocation/customlocations/location1"))
+ .withTags(mapOf("site", "building-1"))
+ .withProperties(new DiscoveredAssetEndpointProfileProperties()
+ .withTargetAddress("https://www.example.com/myTargetAddress")
+ .withAdditionalConfiguration("{\"foo\": \"bar\"}")
+ .withSupportedAuthenticationMethods(Arrays.asList(AuthenticationMethod.ANONYMOUS,
+ AuthenticationMethod.CERTIFICATE, AuthenticationMethod.USERNAME_PASSWORD))
+ .withEndpointProfileType("myEndpointProfileType")
+ .withDiscoveryId("11111111-1111-1111-1111-111111111111")
+ .withVersion(73766L))
+ .create();
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
+```
+
+### DiscoveredAssetEndpointProfiles_Delete
+
+```java
+/**
+ * Samples for DiscoveredAssetEndpointProfiles Delete.
+ */
+public final class DiscoveredAssetEndpointProfilesDeleteSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Delete_DiscoveredAssetEndpointProfile.json
+ */
+ /**
+ * Sample code: Delete_DiscoveredAssetEndpointProfile.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ deleteDiscoveredAssetEndpointProfile(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssetEndpointProfiles()
+ .delete("myResourceGroup", "my-discoveredassetendpointprofile", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssetEndpointProfiles_GetByResourceGroup
+
+```java
+/**
+ * Samples for DiscoveredAssetEndpointProfiles GetByResourceGroup.
+ */
+public final class DiscoveredAssetEndpointProfilesGetByResourceGroupSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_DiscoveredAssetEndpointProfile.json
+ */
+ /**
+ * Sample code: Get_DiscoveredAssetEndpointProfile.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ getDiscoveredAssetEndpointProfile(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssetEndpointProfiles()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-discoveredassetendpointprofile",
+ com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssetEndpointProfiles_List
+
+```java
+/**
+ * Samples for DiscoveredAssetEndpointProfiles List.
+ */
+public final class DiscoveredAssetEndpointProfilesListSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_DiscoveredAssetEndpointProfiles_Subscription.json
+ */
+ /**
+ * Sample code: List_DiscoveredAssetEndpointProfiles_Subscription.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void listDiscoveredAssetEndpointProfilesSubscription(
+ com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssetEndpointProfiles().list(com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssetEndpointProfiles_ListByResourceGroup
+
+```java
+/**
+ * Samples for DiscoveredAssetEndpointProfiles ListByResourceGroup.
+ */
+public final class DiscoveredAssetEndpointProfilesListByResourceGroupSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_DiscoveredAssetEndpointProfiles_ResourceGroup.json
+ */
+ /**
+ * Sample code: List_DiscoveredAssetEndpointProfiles_ResourceGroup.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void listDiscoveredAssetEndpointProfilesResourceGroup(
+ com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssetEndpointProfiles()
+ .listByResourceGroup("myResourceGroup", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssetEndpointProfiles_Update
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.AuthenticationMethod;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfile;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileUpdateProperties;
+import java.util.Arrays;
+
+/**
+ * Samples for DiscoveredAssetEndpointProfiles Update.
+ */
+public final class DiscoveredAssetEndpointProfilesUpdateSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Update_DiscoveredAssetEndpointProfile.json
+ */
+ /**
+ * Sample code: Update_DiscoveredAssetEndpointProfile.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ updateDiscoveredAssetEndpointProfile(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ DiscoveredAssetEndpointProfile resource = manager.discoveredAssetEndpointProfiles()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-discoveredassetendpointprofile",
+ com.azure.core.util.Context.NONE)
+ .getValue();
+ resource.update()
+ .withProperties(new DiscoveredAssetEndpointProfileUpdateProperties()
+ .withTargetAddress("https://www.example.com/myTargetAddress")
+ .withAdditionalConfiguration("{\"foo\": \"bar\"}")
+ .withSupportedAuthenticationMethods(
+ Arrays.asList(AuthenticationMethod.ANONYMOUS, AuthenticationMethod.CERTIFICATE))
+ .withEndpointProfileType("myEndpointProfileType")
+ .withDiscoveryId("11111111-1111-1111-1111-111111111111")
+ .withVersion(73766L))
+ .apply();
+ }
+}
+```
+
+### DiscoveredAssets_CreateOrReplace
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetProperties;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredDataPoint;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredDataset;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredEvent;
+import com.azure.resourcemanager.deviceregistry.models.ExtendedLocation;
+import com.azure.resourcemanager.deviceregistry.models.Topic;
+import com.azure.resourcemanager.deviceregistry.models.TopicRetainType;
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Samples for DiscoveredAssets CreateOrReplace.
+ */
+public final class DiscoveredAssetsCreateOrReplaceSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_DiscoveredAsset.json
+ */
+ /**
+ * Sample code: Create_DiscoveredAsset.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void createDiscoveredAsset(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssets()
+ .define("my-discoveredasset")
+ .withRegion("West Europe")
+ .withExistingResourceGroup("myResourceGroup")
+ .withExtendedLocation(new ExtendedLocation().withType("CustomLocation")
+ .withName(
+ "/subscriptions/00000000-0000-0000-0000-000000000000/resourcegroups/myResourceGroup/providers/microsoft.extendedlocation/customlocations/location1"))
+ .withTags(mapOf("site", "building-1"))
+ .withProperties(new DiscoveredAssetProperties().withAssetEndpointProfileRef("myAssetEndpointProfile")
+ .withDiscoveryId("11111111-1111-1111-1111-111111111111")
+ .withVersion(73766L)
+ .withManufacturer("Contoso")
+ .withManufacturerUri("https://www.contoso.com/manufacturerUri")
+ .withModel("ContosoModel")
+ .withProductCode("fakeTokenPlaceholder")
+ .withHardwareRevision("1.0")
+ .withSoftwareRevision("2.0")
+ .withDocumentationUri("https://www.example.com/manual")
+ .withSerialNumber("64-103816-519918-8")
+ .withDefaultDatasetsConfiguration(
+ "{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultEventsConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withDefaultTopic(new Topic().withPath("/path/defaultTopic").withRetain(TopicRetainType.KEEP))
+ .withDatasets(Arrays.asList(new DiscoveredDataset().withName("dataset1")
+ .withDatasetConfiguration("{\"publishingInterval\":10,\"samplingInterval\":15,\"queueSize\":20}")
+ .withTopic(new Topic().withPath("/path/dataset1").withRetain(TopicRetainType.KEEP))
+ .withDataPoints(Arrays.asList(
+ new DiscoveredDataPoint().withName("dataPoint1")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt1")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":8,\"samplingInterval\":8,\"queueSize\":4}"),
+ new DiscoveredDataPoint().withName("dataPoint2")
+ .withDataSource("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt2")
+ .withDataPointConfiguration(
+ "{\"publishingInterval\":4,\"samplingInterval\":4,\"queueSize\":7}")))))
+ .withEvents(Arrays.asList(
+ new DiscoveredEvent().withName("event1")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt3")
+ .withEventConfiguration("{\"publishingInterval\":7,\"samplingInterval\":1,\"queueSize\":8}")
+ .withTopic(new Topic().withPath("/path/event1").withRetain(TopicRetainType.KEEP)),
+ new DiscoveredEvent().withName("event2")
+ .withEventNotifier("nsu=http://microsoft.com/Opc/OpcPlc/;s=FastUInt4")
+ .withEventConfiguration("{\"publishingInterval\":7,\"samplingInterval\":8,\"queueSize\":4}"))))
+ .create();
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
+```
+
+### DiscoveredAssets_Delete
+
+```java
+/**
+ * Samples for DiscoveredAssets Delete.
+ */
+public final class DiscoveredAssetsDeleteSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Delete_DiscoveredAsset.json
+ */
+ /**
+ * Sample code: Delete_DiscoveredAsset.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void deleteDiscoveredAsset(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssets().delete("myResourceGroup", "my-discoveredasset", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssets_GetByResourceGroup
+
+```java
+/**
+ * Samples for DiscoveredAssets GetByResourceGroup.
+ */
+public final class DiscoveredAssetsGetByResourceGroupSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_DiscoveredAsset.json
+ */
+ /**
+ * Sample code: Get_DiscoveredAsset.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void getDiscoveredAsset(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssets()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-discoveredasset", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssets_List
+
+```java
+/**
+ * Samples for DiscoveredAssets List.
+ */
+public final class DiscoveredAssetsListSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_DiscoveredAssets_Subscription.json
+ */
+ /**
+ * Sample code: List_DiscoveredAssets_Subscription.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ listDiscoveredAssetsSubscription(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssets().list(com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssets_ListByResourceGroup
+
+```java
+/**
+ * Samples for DiscoveredAssets ListByResourceGroup.
+ */
+public final class DiscoveredAssetsListByResourceGroupSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_DiscoveredAssets_ResourceGroup.json
+ */
+ /**
+ * Sample code: List_DiscoveredAssets_ResourceGroup.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ listDiscoveredAssetsResourceGroup(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.discoveredAssets().listByResourceGroup("myResourceGroup", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### DiscoveredAssets_Update
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAsset;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetUpdateProperties;
+import com.azure.resourcemanager.deviceregistry.models.Topic;
+import com.azure.resourcemanager.deviceregistry.models.TopicRetainType;
+
+/**
+ * Samples for DiscoveredAssets Update.
+ */
+public final class DiscoveredAssetsUpdateSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Update_DiscoveredAsset.json
+ */
+ /**
+ * Sample code: Update_DiscoveredAsset.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void updateDiscoveredAsset(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ DiscoveredAsset resource = manager.discoveredAssets()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-discoveredasset", com.azure.core.util.Context.NONE)
+ .getValue();
+ resource.update()
+ .withProperties(
+ new DiscoveredAssetUpdateProperties().withDocumentationUri("https://www.example.com/manual-2")
+ .withDefaultTopic(new Topic().withPath("/path/defaultTopic").withRetain(TopicRetainType.NEVER)))
+ .apply();
+ }
+}
+```
+
+### OperationStatus_Get
+
+```java
+/**
+ * Samples for OperationStatus Get.
+ */
+public final class OperationStatusGetSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_OperationStatus.json
+ */
+ /**
+ * Sample code: Get_OperationStatus.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void getOperationStatus(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.operationStatus()
+ .getWithResponse("testLocation", "xxxxxxxx-xxxx-xxxx-xxxx-xxxxxxxxxxxx", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### Operations_List
+
+```java
+/**
+ * Samples for Operations List.
+ */
+public final class OperationsListSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_Operations.json
+ */
+ /**
+ * Sample code: List_Operations.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void listOperations(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.operations().list(com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### SchemaRegistries_CreateOrReplace
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.SchemaRegistryProperties;
+import com.azure.resourcemanager.deviceregistry.models.SystemAssignedServiceIdentity;
+import com.azure.resourcemanager.deviceregistry.models.SystemAssignedServiceIdentityType;
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Samples for SchemaRegistries CreateOrReplace.
+ */
+public final class SchemaRegistriesCreateOrReplaceSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_SchemaRegistry.json
+ */
+ /**
+ * Sample code: Create_SchemaRegistry.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void createSchemaRegistry(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaRegistries()
+ .define("my-schema-registry")
+ .withRegion("West Europe")
+ .withExistingResourceGroup("myResourceGroup")
+ .withTags(mapOf())
+ .withProperties(new SchemaRegistryProperties().withNamespace("sr-namespace-001")
+ .withDisplayName("Schema Registry namespace 001")
+ .withDescription("This is a sample Schema Registry")
+ .withStorageAccountContainerUrl("my-blob-storage.blob.core.windows.net/my-container"))
+ .withIdentity(new SystemAssignedServiceIdentity().withType(SystemAssignedServiceIdentityType.NONE))
+ .create();
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
+```
+
+### SchemaRegistries_Delete
+
+```java
+/**
+ * Samples for SchemaRegistries Delete.
+ */
+public final class SchemaRegistriesDeleteSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Delete_SchemaRegistry.json
+ */
+ /**
+ * Sample code: Delete_SchemaRegistry.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void deleteSchemaRegistry(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaRegistries().delete("myResourceGroup", "my-schema-registry", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### SchemaRegistries_GetByResourceGroup
+
+```java
+/**
+ * Samples for SchemaRegistries GetByResourceGroup.
+ */
+public final class SchemaRegistriesGetByResourceGroupSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_SchemaRegistry.json
+ */
+ /**
+ * Sample code: Get_SchemaRegistry.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void getSchemaRegistry(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaRegistries()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-schema-registry", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### SchemaRegistries_List
+
+```java
+/**
+ * Samples for SchemaRegistries List.
+ */
+public final class SchemaRegistriesListSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_SchemaRegistries_Subscription.json
+ */
+ /**
+ * Sample code: List_SchemaRegistries_Subscription.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ listSchemaRegistriesSubscription(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaRegistries().list(com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### SchemaRegistries_ListByResourceGroup
+
+```java
+/**
+ * Samples for SchemaRegistries ListByResourceGroup.
+ */
+public final class SchemaRegistriesListByResourceGroupSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_SchemaRegistries_ResourceGroup.json
+ */
+ /**
+ * Sample code: List_SchemaRegistries_ResourceGroup.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ listSchemaRegistriesResourceGroup(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaRegistries().listByResourceGroup("myResourceGroup", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### SchemaRegistries_Update
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.SchemaRegistry;
+import com.azure.resourcemanager.deviceregistry.models.SchemaRegistryUpdateProperties;
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Samples for SchemaRegistries Update.
+ */
+public final class SchemaRegistriesUpdateSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Update_SchemaRegistry.json
+ */
+ /**
+ * Sample code: Update_SchemaRegistry.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void updateSchemaRegistry(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ SchemaRegistry resource = manager.schemaRegistries()
+ .getByResourceGroupWithResponse("myResourceGroup", "my-schema-registry", com.azure.core.util.Context.NONE)
+ .getValue();
+ resource.update()
+ .withTags(mapOf())
+ .withProperties(new SchemaRegistryUpdateProperties().withDisplayName("Schema Registry namespace 001")
+ .withDescription("This is a sample Schema Registry"))
+ .apply();
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
+```
+
+### SchemaVersions_CreateOrReplace
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.SchemaVersionProperties;
+
+/**
+ * Samples for SchemaVersions CreateOrReplace.
+ */
+public final class SchemaVersionsCreateOrReplaceSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_SchemaVersion.json
+ */
+ /**
+ * Sample code: Create_SchemaVersion.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void createSchemaVersion(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaVersions()
+ .define("1")
+ .withExistingSchema("myResourceGroup", "my-schema-registry", "my-schema")
+ .withProperties(new SchemaVersionProperties().withDescription("Schema version 1")
+ .withSchemaContent(
+ "{\"$schema\": \"http://json-schema.org/draft-07/schema#\",\"type\": \"object\",\"properties\": {\"humidity\": {\"type\": \"string\"},\"temperature\": {\"type\":\"number\"}}}"))
+ .create();
+ }
+}
+```
+
+### SchemaVersions_Delete
+
+```java
+/**
+ * Samples for SchemaVersions Delete.
+ */
+public final class SchemaVersionsDeleteSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Delete_SchemaVersion.json
+ */
+ /**
+ * Sample code: Delete_SchemaVersion.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void deleteSchemaVersion(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaVersions()
+ .deleteWithResponse("myResourceGroup", "my-schema-registry", "my-schema", "1",
+ com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### SchemaVersions_Get
+
+```java
+/**
+ * Samples for SchemaVersions Get.
+ */
+public final class SchemaVersionsGetSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_SchemaVersion.json
+ */
+ /**
+ * Sample code: Get_SchemaVersion.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void getSchemaVersion(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaVersions()
+ .getWithResponse("myResourceGroup", "my-schema-registry", "my-schema", "1",
+ com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### SchemaVersions_ListBySchema
+
+```java
+/**
+ * Samples for SchemaVersions ListBySchema.
+ */
+public final class SchemaVersionsListBySchemaSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_SchemaVersions_Schema.json
+ */
+ /**
+ * Sample code: List_SchemaVersions_Schema.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ listSchemaVersionsSchema(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemaVersions()
+ .listBySchema("myResourceGroup", "my-schema-registry", "my-schema", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### Schemas_CreateOrReplace
+
+```java
+import com.azure.resourcemanager.deviceregistry.models.Format;
+import com.azure.resourcemanager.deviceregistry.models.SchemaProperties;
+import com.azure.resourcemanager.deviceregistry.models.SchemaType;
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Samples for Schemas CreateOrReplace.
+ */
+public final class SchemasCreateOrReplaceSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Create_Schema.json
+ */
+ /**
+ * Sample code: Create_Schema.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void createSchema(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemas()
+ .define("my-schema")
+ .withExistingSchemaRegistry("myResourceGroup", "my-schema-registry")
+ .withProperties(new SchemaProperties().withDisplayName("My Schema")
+ .withDescription("This is a sample Schema")
+ .withFormat(Format.JSON_SCHEMA_DRAFT7)
+ .withSchemaType(SchemaType.MESSAGE_SCHEMA)
+ .withTags(mapOf("sampleKey", "fakeTokenPlaceholder")))
+ .create();
+ }
+
+ // Use "Map.of" if available
+ @SuppressWarnings("unchecked")
+ private static Map mapOf(Object... inputs) {
+ Map map = new HashMap<>();
+ for (int i = 0; i < inputs.length; i += 2) {
+ String key = (String) inputs[i];
+ T value = (T) inputs[i + 1];
+ map.put(key, value);
+ }
+ return map;
+ }
+}
+```
+
+### Schemas_Delete
+
+```java
+/**
+ * Samples for Schemas Delete.
+ */
+public final class SchemasDeleteSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Delete_Schema.json
+ */
+ /**
+ * Sample code: Delete_Schema.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void deleteSchema(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemas()
+ .deleteWithResponse("myResourceGroup", "my-schema-registry", "my-schema", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### Schemas_Get
+
+```java
+/**
+ * Samples for Schemas Get.
+ */
+public final class SchemasGetSamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/Get_Schema.json
+ */
+ /**
+ * Sample code: Schemas_Get.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void schemasGet(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemas()
+ .getWithResponse("myResourceGroup", "my-schema-registry", "my-schema", com.azure.core.util.Context.NONE);
+ }
+}
+```
+
+### Schemas_ListBySchemaRegistry
+
+```java
+/**
+ * Samples for Schemas ListBySchemaRegistry.
+ */
+public final class SchemasListBySchemaRegistrySamples {
+ /*
+ * x-ms-original-file: 2024-09-01-preview/List_Schemas_SchemaRegistry.json
+ */
+ /**
+ * Sample code: List_Schemas_SchemaRegistry.
+ *
+ * @param manager Entry point to DeviceRegistryManager.
+ */
+ public static void
+ listSchemasSchemaRegistry(com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager) {
+ manager.schemas()
+ .listBySchemaRegistry("myResourceGroup", "my-schema-registry", com.azure.core.util.Context.NONE);
}
}
```
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/pom.xml b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/pom.xml
index 96277cb6ae65..8366fc35e5f0 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/pom.xml
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/pom.xml
@@ -1,7 +1,7 @@
4.0.0
@@ -14,7 +14,7 @@ Code generated by Microsoft (R) TypeSpec Code Generator.
com.azure.resourcemanager
azure-resourcemanager-deviceregistry
- 1.0.0-beta.2
+ 1.0.0-beta.3
jar
Microsoft Azure SDK for Device Registry Management
@@ -46,13 +46,9 @@ Code generated by Microsoft (R) TypeSpec Code Generator.
0
0
true
+ false
-
- com.azure
- azure-json
- 1.3.0
-
com.azure
azure-core
@@ -75,5 +71,10 @@ Code generated by Microsoft (R) TypeSpec Code Generator.
1.14.2
test
+
+ com.azure
+ azure-json
+ 1.3.0
+
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/DeviceRegistryManager.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/DeviceRegistryManager.java
index d2f6a321e567..1f39c58fce5d 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/DeviceRegistryManager.java
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/DeviceRegistryManager.java
@@ -23,16 +23,28 @@
import com.azure.core.management.profile.AzureProfile;
import com.azure.core.util.Configuration;
import com.azure.core.util.logging.ClientLogger;
-import com.azure.resourcemanager.deviceregistry.fluent.DeviceRegistryClient;
+import com.azure.resourcemanager.deviceregistry.fluent.DeviceRegistryManagementClient;
import com.azure.resourcemanager.deviceregistry.implementation.AssetEndpointProfilesImpl;
import com.azure.resourcemanager.deviceregistry.implementation.AssetsImpl;
-import com.azure.resourcemanager.deviceregistry.implementation.DeviceRegistryClientBuilder;
+import com.azure.resourcemanager.deviceregistry.implementation.BillingContainersImpl;
+import com.azure.resourcemanager.deviceregistry.implementation.DeviceRegistryManagementClientBuilder;
+import com.azure.resourcemanager.deviceregistry.implementation.DiscoveredAssetEndpointProfilesImpl;
+import com.azure.resourcemanager.deviceregistry.implementation.DiscoveredAssetsImpl;
import com.azure.resourcemanager.deviceregistry.implementation.OperationStatusImpl;
import com.azure.resourcemanager.deviceregistry.implementation.OperationsImpl;
+import com.azure.resourcemanager.deviceregistry.implementation.SchemaRegistriesImpl;
+import com.azure.resourcemanager.deviceregistry.implementation.SchemaVersionsImpl;
+import com.azure.resourcemanager.deviceregistry.implementation.SchemasImpl;
import com.azure.resourcemanager.deviceregistry.models.AssetEndpointProfiles;
import com.azure.resourcemanager.deviceregistry.models.Assets;
+import com.azure.resourcemanager.deviceregistry.models.BillingContainers;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfiles;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssets;
import com.azure.resourcemanager.deviceregistry.models.OperationStatus;
import com.azure.resourcemanager.deviceregistry.models.Operations;
+import com.azure.resourcemanager.deviceregistry.models.SchemaRegistries;
+import com.azure.resourcemanager.deviceregistry.models.SchemaVersions;
+import com.azure.resourcemanager.deviceregistry.models.Schemas;
import java.time.Duration;
import java.time.temporal.ChronoUnit;
import java.util.ArrayList;
@@ -53,12 +65,24 @@ public final class DeviceRegistryManager {
private AssetEndpointProfiles assetEndpointProfiles;
- private final DeviceRegistryClient clientObject;
+ private BillingContainers billingContainers;
+
+ private DiscoveredAssets discoveredAssets;
+
+ private DiscoveredAssetEndpointProfiles discoveredAssetEndpointProfiles;
+
+ private SchemaRegistries schemaRegistries;
+
+ private Schemas schemas;
+
+ private SchemaVersions schemaVersions;
+
+ private final DeviceRegistryManagementClient clientObject;
private DeviceRegistryManager(HttpPipeline httpPipeline, AzureProfile profile, Duration defaultPollInterval) {
Objects.requireNonNull(httpPipeline, "'httpPipeline' cannot be null.");
Objects.requireNonNull(profile, "'profile' cannot be null.");
- this.clientObject = new DeviceRegistryClientBuilder().pipeline(httpPipeline)
+ this.clientObject = new DeviceRegistryManagementClientBuilder().pipeline(httpPipeline)
.endpoint(profile.getEnvironment().getResourceManagerEndpoint())
.subscriptionId(profile.getSubscriptionId())
.defaultPollInterval(defaultPollInterval)
@@ -312,12 +336,85 @@ public AssetEndpointProfiles assetEndpointProfiles() {
}
/**
- * Gets wrapped service client DeviceRegistryClient providing direct access to the underlying auto-generated API
- * implementation, based on Azure REST API.
+ * Gets the resource collection API of BillingContainers.
+ *
+ * @return Resource collection API of BillingContainers.
+ */
+ public BillingContainers billingContainers() {
+ if (this.billingContainers == null) {
+ this.billingContainers = new BillingContainersImpl(clientObject.getBillingContainers(), this);
+ }
+ return billingContainers;
+ }
+
+ /**
+ * Gets the resource collection API of DiscoveredAssets. It manages DiscoveredAsset.
+ *
+ * @return Resource collection API of DiscoveredAssets.
+ */
+ public DiscoveredAssets discoveredAssets() {
+ if (this.discoveredAssets == null) {
+ this.discoveredAssets = new DiscoveredAssetsImpl(clientObject.getDiscoveredAssets(), this);
+ }
+ return discoveredAssets;
+ }
+
+ /**
+ * Gets the resource collection API of DiscoveredAssetEndpointProfiles. It manages DiscoveredAssetEndpointProfile.
+ *
+ * @return Resource collection API of DiscoveredAssetEndpointProfiles.
+ */
+ public DiscoveredAssetEndpointProfiles discoveredAssetEndpointProfiles() {
+ if (this.discoveredAssetEndpointProfiles == null) {
+ this.discoveredAssetEndpointProfiles
+ = new DiscoveredAssetEndpointProfilesImpl(clientObject.getDiscoveredAssetEndpointProfiles(), this);
+ }
+ return discoveredAssetEndpointProfiles;
+ }
+
+ /**
+ * Gets the resource collection API of SchemaRegistries. It manages SchemaRegistry.
+ *
+ * @return Resource collection API of SchemaRegistries.
+ */
+ public SchemaRegistries schemaRegistries() {
+ if (this.schemaRegistries == null) {
+ this.schemaRegistries = new SchemaRegistriesImpl(clientObject.getSchemaRegistries(), this);
+ }
+ return schemaRegistries;
+ }
+
+ /**
+ * Gets the resource collection API of Schemas. It manages Schema.
+ *
+ * @return Resource collection API of Schemas.
+ */
+ public Schemas schemas() {
+ if (this.schemas == null) {
+ this.schemas = new SchemasImpl(clientObject.getSchemas(), this);
+ }
+ return schemas;
+ }
+
+ /**
+ * Gets the resource collection API of SchemaVersions. It manages SchemaVersion.
+ *
+ * @return Resource collection API of SchemaVersions.
+ */
+ public SchemaVersions schemaVersions() {
+ if (this.schemaVersions == null) {
+ this.schemaVersions = new SchemaVersionsImpl(clientObject.getSchemaVersions(), this);
+ }
+ return schemaVersions;
+ }
+
+ /**
+ * Gets wrapped service client DeviceRegistryManagementClient providing direct access to the underlying
+ * auto-generated API implementation, based on Azure REST API.
*
- * @return Wrapped service client DeviceRegistryClient.
+ * @return Wrapped service client DeviceRegistryManagementClient.
*/
- public DeviceRegistryClient serviceClient() {
+ public DeviceRegistryManagementClient serviceClient() {
return this.clientObject;
}
}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/BillingContainersClient.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/BillingContainersClient.java
new file mode 100644
index 000000000000..37701d41d754
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/BillingContainersClient.java
@@ -0,0 +1,64 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent;
+
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.Response;
+import com.azure.core.util.Context;
+import com.azure.resourcemanager.deviceregistry.fluent.models.BillingContainerInner;
+
+/**
+ * An instance of this class provides access to all the operations defined in BillingContainersClient.
+ */
+public interface BillingContainersClient {
+ /**
+ * Get a BillingContainer.
+ *
+ * @param billingContainerName Name of the billing container.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a BillingContainer along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response getWithResponse(String billingContainerName, Context context);
+
+ /**
+ * Get a BillingContainer.
+ *
+ * @param billingContainerName Name of the billing container.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a BillingContainer.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ BillingContainerInner get(String billingContainerName);
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list();
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list(Context context);
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DeviceRegistryClient.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DeviceRegistryManagementClient.java
similarity index 57%
rename from sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DeviceRegistryClient.java
rename to sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DeviceRegistryManagementClient.java
index e2bfee52a58b..6e64e3324c3a 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DeviceRegistryClient.java
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DeviceRegistryManagementClient.java
@@ -8,9 +8,9 @@
import java.time.Duration;
/**
- * The interface for DeviceRegistryClient class.
+ * The interface for DeviceRegistryManagementClient class.
*/
-public interface DeviceRegistryClient {
+public interface DeviceRegistryManagementClient {
/**
* Gets Service host.
*
@@ -73,4 +73,46 @@ public interface DeviceRegistryClient {
* @return the AssetEndpointProfilesClient object.
*/
AssetEndpointProfilesClient getAssetEndpointProfiles();
+
+ /**
+ * Gets the BillingContainersClient object to access its operations.
+ *
+ * @return the BillingContainersClient object.
+ */
+ BillingContainersClient getBillingContainers();
+
+ /**
+ * Gets the DiscoveredAssetsClient object to access its operations.
+ *
+ * @return the DiscoveredAssetsClient object.
+ */
+ DiscoveredAssetsClient getDiscoveredAssets();
+
+ /**
+ * Gets the DiscoveredAssetEndpointProfilesClient object to access its operations.
+ *
+ * @return the DiscoveredAssetEndpointProfilesClient object.
+ */
+ DiscoveredAssetEndpointProfilesClient getDiscoveredAssetEndpointProfiles();
+
+ /**
+ * Gets the SchemaRegistriesClient object to access its operations.
+ *
+ * @return the SchemaRegistriesClient object.
+ */
+ SchemaRegistriesClient getSchemaRegistries();
+
+ /**
+ * Gets the SchemasClient object to access its operations.
+ *
+ * @return the SchemasClient object.
+ */
+ SchemasClient getSchemas();
+
+ /**
+ * Gets the SchemaVersionsClient object to access its operations.
+ *
+ * @return the SchemaVersionsClient object.
+ */
+ SchemaVersionsClient getSchemaVersions();
}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DiscoveredAssetEndpointProfilesClient.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DiscoveredAssetEndpointProfilesClient.java
new file mode 100644
index 000000000000..07d2ea342172
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DiscoveredAssetEndpointProfilesClient.java
@@ -0,0 +1,281 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent;
+
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.Response;
+import com.azure.core.management.polling.PollResult;
+import com.azure.core.util.Context;
+import com.azure.core.util.polling.SyncPoller;
+import com.azure.resourcemanager.deviceregistry.fluent.models.DiscoveredAssetEndpointProfileInner;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileUpdate;
+
+/**
+ * An instance of this class provides access to all the operations defined in DiscoveredAssetEndpointProfilesClient.
+ */
+public interface DiscoveredAssetEndpointProfilesClient {
+ /**
+ * Get a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a DiscoveredAssetEndpointProfile along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response getByResourceGroupWithResponse(String resourceGroupName,
+ String discoveredAssetEndpointProfileName, Context context);
+
+ /**
+ * Get a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a DiscoveredAssetEndpointProfile.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetEndpointProfileInner getByResourceGroup(String resourceGroupName,
+ String discoveredAssetEndpointProfileName);
+
+ /**
+ * Create a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetEndpointProfileInner>
+ beginCreateOrReplace(String resourceGroupName, String discoveredAssetEndpointProfileName,
+ DiscoveredAssetEndpointProfileInner resource);
+
+ /**
+ * Create a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetEndpointProfileInner>
+ beginCreateOrReplace(String resourceGroupName, String discoveredAssetEndpointProfileName,
+ DiscoveredAssetEndpointProfileInner resource, Context context);
+
+ /**
+ * Create a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetEndpointProfileInner createOrReplace(String resourceGroupName,
+ String discoveredAssetEndpointProfileName, DiscoveredAssetEndpointProfileInner resource);
+
+ /**
+ * Create a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetEndpointProfileInner createOrReplace(String resourceGroupName,
+ String discoveredAssetEndpointProfileName, DiscoveredAssetEndpointProfileInner resource, Context context);
+
+ /**
+ * Update a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param properties The resource properties to be updated.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetEndpointProfileInner> beginUpdate(
+ String resourceGroupName, String discoveredAssetEndpointProfileName,
+ DiscoveredAssetEndpointProfileUpdate properties);
+
+ /**
+ * Update a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param properties The resource properties to be updated.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetEndpointProfileInner> beginUpdate(
+ String resourceGroupName, String discoveredAssetEndpointProfileName,
+ DiscoveredAssetEndpointProfileUpdate properties, Context context);
+
+ /**
+ * Update a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param properties The resource properties to be updated.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetEndpointProfileInner update(String resourceGroupName, String discoveredAssetEndpointProfileName,
+ DiscoveredAssetEndpointProfileUpdate properties);
+
+ /**
+ * Update a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param properties The resource properties to be updated.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset Endpoint Profile definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetEndpointProfileInner update(String resourceGroupName, String discoveredAssetEndpointProfileName,
+ DiscoveredAssetEndpointProfileUpdate properties, Context context);
+
+ /**
+ * Delete a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of long-running operation.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, Void> beginDelete(String resourceGroupName, String discoveredAssetEndpointProfileName);
+
+ /**
+ * Delete a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of long-running operation.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, Void> beginDelete(String resourceGroupName, String discoveredAssetEndpointProfileName,
+ Context context);
+
+ /**
+ * Delete a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String discoveredAssetEndpointProfileName);
+
+ /**
+ * Delete a DiscoveredAssetEndpointProfile.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetEndpointProfileName Discovered Asset Endpoint Profile name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String discoveredAssetEndpointProfileName, Context context);
+
+ /**
+ * List DiscoveredAssetEndpointProfile resources by resource group.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAssetEndpointProfile list operation as paginated response with
+ * {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listByResourceGroup(String resourceGroupName);
+
+ /**
+ * List DiscoveredAssetEndpointProfile resources by resource group.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAssetEndpointProfile list operation as paginated response with
+ * {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listByResourceGroup(String resourceGroupName, Context context);
+
+ /**
+ * List DiscoveredAssetEndpointProfile resources by subscription ID.
+ *
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAssetEndpointProfile list operation as paginated response with
+ * {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list();
+
+ /**
+ * List DiscoveredAssetEndpointProfile resources by subscription ID.
+ *
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAssetEndpointProfile list operation as paginated response with
+ * {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list(Context context);
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DiscoveredAssetsClient.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DiscoveredAssetsClient.java
new file mode 100644
index 000000000000..3362c3d1e02f
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/DiscoveredAssetsClient.java
@@ -0,0 +1,271 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent;
+
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.Response;
+import com.azure.core.management.polling.PollResult;
+import com.azure.core.util.Context;
+import com.azure.core.util.polling.SyncPoller;
+import com.azure.resourcemanager.deviceregistry.fluent.models.DiscoveredAssetInner;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetUpdate;
+
+/**
+ * An instance of this class provides access to all the operations defined in DiscoveredAssetsClient.
+ */
+public interface DiscoveredAssetsClient {
+ /**
+ * Get a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a DiscoveredAsset along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response getByResourceGroupWithResponse(String resourceGroupName, String discoveredAssetName,
+ Context context);
+
+ /**
+ * Get a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a DiscoveredAsset.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetInner getByResourceGroup(String resourceGroupName, String discoveredAssetName);
+
+ /**
+ * Create a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetInner> beginCreateOrReplace(String resourceGroupName,
+ String discoveredAssetName, DiscoveredAssetInner resource);
+
+ /**
+ * Create a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetInner> beginCreateOrReplace(String resourceGroupName,
+ String discoveredAssetName, DiscoveredAssetInner resource, Context context);
+
+ /**
+ * Create a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetInner createOrReplace(String resourceGroupName, String discoveredAssetName,
+ DiscoveredAssetInner resource);
+
+ /**
+ * Create a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetInner createOrReplace(String resourceGroupName, String discoveredAssetName,
+ DiscoveredAssetInner resource, Context context);
+
+ /**
+ * Update a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param properties The resource properties to be updated.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetInner> beginUpdate(String resourceGroupName,
+ String discoveredAssetName, DiscoveredAssetUpdate properties);
+
+ /**
+ * Update a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param properties The resource properties to be updated.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, DiscoveredAssetInner> beginUpdate(String resourceGroupName,
+ String discoveredAssetName, DiscoveredAssetUpdate properties, Context context);
+
+ /**
+ * Update a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param properties The resource properties to be updated.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetInner update(String resourceGroupName, String discoveredAssetName, DiscoveredAssetUpdate properties);
+
+ /**
+ * Update a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param properties The resource properties to be updated.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return discovered Asset definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ DiscoveredAssetInner update(String resourceGroupName, String discoveredAssetName, DiscoveredAssetUpdate properties,
+ Context context);
+
+ /**
+ * Delete a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of long-running operation.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, Void> beginDelete(String resourceGroupName, String discoveredAssetName);
+
+ /**
+ * Delete a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of long-running operation.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, Void> beginDelete(String resourceGroupName, String discoveredAssetName,
+ Context context);
+
+ /**
+ * Delete a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String discoveredAssetName);
+
+ /**
+ * Delete a DiscoveredAsset.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param discoveredAssetName Discovered Asset name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String discoveredAssetName, Context context);
+
+ /**
+ * List DiscoveredAsset resources by resource group.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAsset list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listByResourceGroup(String resourceGroupName);
+
+ /**
+ * List DiscoveredAsset resources by resource group.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAsset list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listByResourceGroup(String resourceGroupName, Context context);
+
+ /**
+ * List DiscoveredAsset resources by subscription ID.
+ *
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAsset list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list();
+
+ /**
+ * List DiscoveredAsset resources by subscription ID.
+ *
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a DiscoveredAsset list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list(Context context);
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemaRegistriesClient.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemaRegistriesClient.java
new file mode 100644
index 000000000000..cea69f6ae34f
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemaRegistriesClient.java
@@ -0,0 +1,271 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent;
+
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.Response;
+import com.azure.core.management.polling.PollResult;
+import com.azure.core.util.Context;
+import com.azure.core.util.polling.SyncPoller;
+import com.azure.resourcemanager.deviceregistry.fluent.models.SchemaRegistryInner;
+import com.azure.resourcemanager.deviceregistry.models.SchemaRegistryUpdate;
+
+/**
+ * An instance of this class provides access to all the operations defined in SchemaRegistriesClient.
+ */
+public interface SchemaRegistriesClient {
+ /**
+ * Get a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a SchemaRegistry along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response getByResourceGroupWithResponse(String resourceGroupName, String schemaRegistryName,
+ Context context);
+
+ /**
+ * Get a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a SchemaRegistry.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaRegistryInner getByResourceGroup(String resourceGroupName, String schemaRegistryName);
+
+ /**
+ * Create a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, SchemaRegistryInner> beginCreateOrReplace(String resourceGroupName,
+ String schemaRegistryName, SchemaRegistryInner resource);
+
+ /**
+ * Create a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, SchemaRegistryInner> beginCreateOrReplace(String resourceGroupName,
+ String schemaRegistryName, SchemaRegistryInner resource, Context context);
+
+ /**
+ * Create a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaRegistryInner createOrReplace(String resourceGroupName, String schemaRegistryName,
+ SchemaRegistryInner resource);
+
+ /**
+ * Create a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaRegistryInner createOrReplace(String resourceGroupName, String schemaRegistryName,
+ SchemaRegistryInner resource, Context context);
+
+ /**
+ * Update a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param properties The resource properties to be updated.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, SchemaRegistryInner> beginUpdate(String resourceGroupName,
+ String schemaRegistryName, SchemaRegistryUpdate properties);
+
+ /**
+ * Update a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param properties The resource properties to be updated.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, SchemaRegistryInner> beginUpdate(String resourceGroupName,
+ String schemaRegistryName, SchemaRegistryUpdate properties, Context context);
+
+ /**
+ * Update a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param properties The resource properties to be updated.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaRegistryInner update(String resourceGroupName, String schemaRegistryName, SchemaRegistryUpdate properties);
+
+ /**
+ * Update a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param properties The resource properties to be updated.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema registry definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaRegistryInner update(String resourceGroupName, String schemaRegistryName, SchemaRegistryUpdate properties,
+ Context context);
+
+ /**
+ * Delete a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of long-running operation.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, Void> beginDelete(String resourceGroupName, String schemaRegistryName);
+
+ /**
+ * Delete a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link SyncPoller} for polling of long-running operation.
+ */
+ @ServiceMethod(returns = ReturnType.LONG_RUNNING_OPERATION)
+ SyncPoller, Void> beginDelete(String resourceGroupName, String schemaRegistryName,
+ Context context);
+
+ /**
+ * Delete a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String schemaRegistryName);
+
+ /**
+ * Delete a SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String schemaRegistryName, Context context);
+
+ /**
+ * List SchemaRegistry resources by resource group.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a SchemaRegistry list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listByResourceGroup(String resourceGroupName);
+
+ /**
+ * List SchemaRegistry resources by resource group.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a SchemaRegistry list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listByResourceGroup(String resourceGroupName, Context context);
+
+ /**
+ * List SchemaRegistry resources by subscription ID.
+ *
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a SchemaRegistry list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list();
+
+ /**
+ * List SchemaRegistry resources by subscription ID.
+ *
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a SchemaRegistry list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable list(Context context);
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemaVersionsClient.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemaVersionsClient.java
new file mode 100644
index 000000000000..5241f1271986
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemaVersionsClient.java
@@ -0,0 +1,147 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent;
+
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.Response;
+import com.azure.core.util.Context;
+import com.azure.resourcemanager.deviceregistry.fluent.models.SchemaVersionInner;
+
+/**
+ * An instance of this class provides access to all the operations defined in SchemaVersionsClient.
+ */
+public interface SchemaVersionsClient {
+ /**
+ * Get a SchemaVersion.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param schemaVersionName Schema version name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a SchemaVersion along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response getWithResponse(String resourceGroupName, String schemaRegistryName, String schemaName,
+ String schemaVersionName, Context context);
+
+ /**
+ * Get a SchemaVersion.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param schemaVersionName Schema version name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a SchemaVersion.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaVersionInner get(String resourceGroupName, String schemaRegistryName, String schemaName,
+ String schemaVersionName);
+
+ /**
+ * Create a SchemaVersion.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param schemaVersionName Schema version name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema version's definition along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response createOrReplaceWithResponse(String resourceGroupName, String schemaRegistryName,
+ String schemaName, String schemaVersionName, SchemaVersionInner resource, Context context);
+
+ /**
+ * Create a SchemaVersion.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param schemaVersionName Schema version name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema version's definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaVersionInner createOrReplace(String resourceGroupName, String schemaRegistryName, String schemaName,
+ String schemaVersionName, SchemaVersionInner resource);
+
+ /**
+ * Delete a SchemaVersion.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param schemaVersionName Schema version name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response deleteWithResponse(String resourceGroupName, String schemaRegistryName, String schemaName,
+ String schemaVersionName, Context context);
+
+ /**
+ * Delete a SchemaVersion.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param schemaVersionName Schema version name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String schemaRegistryName, String schemaName, String schemaVersionName);
+
+ /**
+ * List SchemaVersion resources by Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a SchemaVersion list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listBySchema(String resourceGroupName, String schemaRegistryName,
+ String schemaName);
+
+ /**
+ * List SchemaVersion resources by Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a SchemaVersion list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listBySchema(String resourceGroupName, String schemaRegistryName,
+ String schemaName, Context context);
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemasClient.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemasClient.java
new file mode 100644
index 000000000000..4bd64cc2174e
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/SchemasClient.java
@@ -0,0 +1,137 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent;
+
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.Response;
+import com.azure.core.util.Context;
+import com.azure.resourcemanager.deviceregistry.fluent.models.SchemaInner;
+
+/**
+ * An instance of this class provides access to all the operations defined in SchemasClient.
+ */
+public interface SchemasClient {
+ /**
+ * Get a Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a Schema along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response getWithResponse(String resourceGroupName, String schemaRegistryName, String schemaName,
+ Context context);
+
+ /**
+ * Get a Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a Schema.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaInner get(String resourceGroupName, String schemaRegistryName, String schemaName);
+
+ /**
+ * Create a Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param resource Resource create parameters.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema definition along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response createOrReplaceWithResponse(String resourceGroupName, String schemaRegistryName,
+ String schemaName, SchemaInner resource, Context context);
+
+ /**
+ * Create a Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param resource Resource create parameters.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return schema definition.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ SchemaInner createOrReplace(String resourceGroupName, String schemaRegistryName, String schemaName,
+ SchemaInner resource);
+
+ /**
+ * Delete a Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ Response deleteWithResponse(String resourceGroupName, String schemaRegistryName, String schemaName,
+ Context context);
+
+ /**
+ * Delete a Schema.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param schemaName Schema name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ void delete(String resourceGroupName, String schemaRegistryName, String schemaName);
+
+ /**
+ * List Schema resources by SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a Schema list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listBySchemaRegistry(String resourceGroupName, String schemaRegistryName);
+
+ /**
+ * List Schema resources by SchemaRegistry.
+ *
+ * @param resourceGroupName The name of the resource group. The name is case insensitive.
+ * @param schemaRegistryName Schema registry name parameter.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws com.azure.core.management.exception.ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a Schema list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ PagedIterable listBySchemaRegistry(String resourceGroupName, String schemaRegistryName,
+ Context context);
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/BillingContainerInner.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/BillingContainerInner.java
new file mode 100644
index 000000000000..2c70351f8a43
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/BillingContainerInner.java
@@ -0,0 +1,172 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent.models;
+
+import com.azure.core.annotation.Immutable;
+import com.azure.core.management.ProxyResource;
+import com.azure.core.management.SystemData;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import com.azure.resourcemanager.deviceregistry.models.BillingContainerProperties;
+import java.io.IOException;
+
+/**
+ * billingContainer Model as Azure resource whose sole purpose is to keep track of billables resources under a
+ * subscription.
+ */
+@Immutable
+public final class BillingContainerInner extends ProxyResource {
+ /*
+ * The resource-specific properties for this resource.
+ */
+ private BillingContainerProperties properties;
+
+ /*
+ * Resource ETag
+ */
+ private String etag;
+
+ /*
+ * Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ */
+ private SystemData systemData;
+
+ /*
+ * The type of the resource.
+ */
+ private String type;
+
+ /*
+ * The name of the resource.
+ */
+ private String name;
+
+ /*
+ * Fully qualified resource Id for the resource.
+ */
+ private String id;
+
+ /**
+ * Creates an instance of BillingContainerInner class.
+ */
+ private BillingContainerInner() {
+ }
+
+ /**
+ * Get the properties property: The resource-specific properties for this resource.
+ *
+ * @return the properties value.
+ */
+ public BillingContainerProperties properties() {
+ return this.properties;
+ }
+
+ /**
+ * Get the etag property: Resource ETag.
+ *
+ * @return the etag value.
+ */
+ public String etag() {
+ return this.etag;
+ }
+
+ /**
+ * Get the systemData property: Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ *
+ * @return the systemData value.
+ */
+ public SystemData systemData() {
+ return this.systemData;
+ }
+
+ /**
+ * Get the type property: The type of the resource.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Get the name property: The name of the resource.
+ *
+ * @return the name value.
+ */
+ @Override
+ public String name() {
+ return this.name;
+ }
+
+ /**
+ * Get the id property: Fully qualified resource Id for the resource.
+ *
+ * @return the id value.
+ */
+ @Override
+ public String id() {
+ return this.id;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ public void validate() {
+ if (properties() != null) {
+ properties().validate();
+ }
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeJsonField("properties", this.properties);
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of BillingContainerInner from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of BillingContainerInner if the JsonReader was pointing to an instance of it, or null if it
+ * was pointing to JSON null.
+ * @throws IllegalStateException If the deserialized JSON object was missing any required properties.
+ * @throws IOException If an error occurs while reading the BillingContainerInner.
+ */
+ public static BillingContainerInner fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ BillingContainerInner deserializedBillingContainerInner = new BillingContainerInner();
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("id".equals(fieldName)) {
+ deserializedBillingContainerInner.id = reader.getString();
+ } else if ("name".equals(fieldName)) {
+ deserializedBillingContainerInner.name = reader.getString();
+ } else if ("type".equals(fieldName)) {
+ deserializedBillingContainerInner.type = reader.getString();
+ } else if ("properties".equals(fieldName)) {
+ deserializedBillingContainerInner.properties = BillingContainerProperties.fromJson(reader);
+ } else if ("etag".equals(fieldName)) {
+ deserializedBillingContainerInner.etag = reader.getString();
+ } else if ("systemData".equals(fieldName)) {
+ deserializedBillingContainerInner.systemData = SystemData.fromJson(reader);
+ } else {
+ reader.skipChildren();
+ }
+ }
+
+ return deserializedBillingContainerInner;
+ });
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/DiscoveredAssetEndpointProfileInner.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/DiscoveredAssetEndpointProfileInner.java
new file mode 100644
index 000000000000..44ef009c51ad
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/DiscoveredAssetEndpointProfileInner.java
@@ -0,0 +1,234 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent.models;
+
+import com.azure.core.annotation.Fluent;
+import com.azure.core.management.Resource;
+import com.azure.core.management.SystemData;
+import com.azure.core.util.logging.ClientLogger;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileProperties;
+import com.azure.resourcemanager.deviceregistry.models.ExtendedLocation;
+import java.io.IOException;
+import java.util.Map;
+
+/**
+ * Discovered Asset Endpoint Profile definition.
+ */
+@Fluent
+public final class DiscoveredAssetEndpointProfileInner extends Resource {
+ /*
+ * The resource-specific properties for this resource.
+ */
+ private DiscoveredAssetEndpointProfileProperties properties;
+
+ /*
+ * The extended location.
+ */
+ private ExtendedLocation extendedLocation;
+
+ /*
+ * Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ */
+ private SystemData systemData;
+
+ /*
+ * The type of the resource.
+ */
+ private String type;
+
+ /*
+ * The name of the resource.
+ */
+ private String name;
+
+ /*
+ * Fully qualified resource Id for the resource.
+ */
+ private String id;
+
+ /**
+ * Creates an instance of DiscoveredAssetEndpointProfileInner class.
+ */
+ public DiscoveredAssetEndpointProfileInner() {
+ }
+
+ /**
+ * Get the properties property: The resource-specific properties for this resource.
+ *
+ * @return the properties value.
+ */
+ public DiscoveredAssetEndpointProfileProperties properties() {
+ return this.properties;
+ }
+
+ /**
+ * Set the properties property: The resource-specific properties for this resource.
+ *
+ * @param properties the properties value to set.
+ * @return the DiscoveredAssetEndpointProfileInner object itself.
+ */
+ public DiscoveredAssetEndpointProfileInner withProperties(DiscoveredAssetEndpointProfileProperties properties) {
+ this.properties = properties;
+ return this;
+ }
+
+ /**
+ * Get the extendedLocation property: The extended location.
+ *
+ * @return the extendedLocation value.
+ */
+ public ExtendedLocation extendedLocation() {
+ return this.extendedLocation;
+ }
+
+ /**
+ * Set the extendedLocation property: The extended location.
+ *
+ * @param extendedLocation the extendedLocation value to set.
+ * @return the DiscoveredAssetEndpointProfileInner object itself.
+ */
+ public DiscoveredAssetEndpointProfileInner withExtendedLocation(ExtendedLocation extendedLocation) {
+ this.extendedLocation = extendedLocation;
+ return this;
+ }
+
+ /**
+ * Get the systemData property: Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ *
+ * @return the systemData value.
+ */
+ public SystemData systemData() {
+ return this.systemData;
+ }
+
+ /**
+ * Get the type property: The type of the resource.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Get the name property: The name of the resource.
+ *
+ * @return the name value.
+ */
+ @Override
+ public String name() {
+ return this.name;
+ }
+
+ /**
+ * Get the id property: Fully qualified resource Id for the resource.
+ *
+ * @return the id value.
+ */
+ @Override
+ public String id() {
+ return this.id;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public DiscoveredAssetEndpointProfileInner withLocation(String location) {
+ super.withLocation(location);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public DiscoveredAssetEndpointProfileInner withTags(Map tags) {
+ super.withTags(tags);
+ return this;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ public void validate() {
+ if (properties() != null) {
+ properties().validate();
+ }
+ if (extendedLocation() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property extendedLocation in model DiscoveredAssetEndpointProfileInner"));
+ } else {
+ extendedLocation().validate();
+ }
+ }
+
+ private static final ClientLogger LOGGER = new ClientLogger(DiscoveredAssetEndpointProfileInner.class);
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeStringField("location", location());
+ jsonWriter.writeMapField("tags", tags(), (writer, element) -> writer.writeString(element));
+ jsonWriter.writeJsonField("extendedLocation", this.extendedLocation);
+ jsonWriter.writeJsonField("properties", this.properties);
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of DiscoveredAssetEndpointProfileInner from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of DiscoveredAssetEndpointProfileInner if the JsonReader was pointing to an instance of it,
+ * or null if it was pointing to JSON null.
+ * @throws IllegalStateException If the deserialized JSON object was missing any required properties.
+ * @throws IOException If an error occurs while reading the DiscoveredAssetEndpointProfileInner.
+ */
+ public static DiscoveredAssetEndpointProfileInner fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ DiscoveredAssetEndpointProfileInner deserializedDiscoveredAssetEndpointProfileInner
+ = new DiscoveredAssetEndpointProfileInner();
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("id".equals(fieldName)) {
+ deserializedDiscoveredAssetEndpointProfileInner.id = reader.getString();
+ } else if ("name".equals(fieldName)) {
+ deserializedDiscoveredAssetEndpointProfileInner.name = reader.getString();
+ } else if ("type".equals(fieldName)) {
+ deserializedDiscoveredAssetEndpointProfileInner.type = reader.getString();
+ } else if ("location".equals(fieldName)) {
+ deserializedDiscoveredAssetEndpointProfileInner.withLocation(reader.getString());
+ } else if ("tags".equals(fieldName)) {
+ Map tags = reader.readMap(reader1 -> reader1.getString());
+ deserializedDiscoveredAssetEndpointProfileInner.withTags(tags);
+ } else if ("extendedLocation".equals(fieldName)) {
+ deserializedDiscoveredAssetEndpointProfileInner.extendedLocation
+ = ExtendedLocation.fromJson(reader);
+ } else if ("properties".equals(fieldName)) {
+ deserializedDiscoveredAssetEndpointProfileInner.properties
+ = DiscoveredAssetEndpointProfileProperties.fromJson(reader);
+ } else if ("systemData".equals(fieldName)) {
+ deserializedDiscoveredAssetEndpointProfileInner.systemData = SystemData.fromJson(reader);
+ } else {
+ reader.skipChildren();
+ }
+ }
+
+ return deserializedDiscoveredAssetEndpointProfileInner;
+ });
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/DiscoveredAssetInner.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/DiscoveredAssetInner.java
new file mode 100644
index 000000000000..366bebe17b20
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/DiscoveredAssetInner.java
@@ -0,0 +1,231 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent.models;
+
+import com.azure.core.annotation.Fluent;
+import com.azure.core.management.Resource;
+import com.azure.core.management.SystemData;
+import com.azure.core.util.logging.ClientLogger;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetProperties;
+import com.azure.resourcemanager.deviceregistry.models.ExtendedLocation;
+import java.io.IOException;
+import java.util.Map;
+
+/**
+ * Discovered Asset definition.
+ */
+@Fluent
+public final class DiscoveredAssetInner extends Resource {
+ /*
+ * The resource-specific properties for this resource.
+ */
+ private DiscoveredAssetProperties properties;
+
+ /*
+ * The extended location.
+ */
+ private ExtendedLocation extendedLocation;
+
+ /*
+ * Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ */
+ private SystemData systemData;
+
+ /*
+ * The type of the resource.
+ */
+ private String type;
+
+ /*
+ * The name of the resource.
+ */
+ private String name;
+
+ /*
+ * Fully qualified resource Id for the resource.
+ */
+ private String id;
+
+ /**
+ * Creates an instance of DiscoveredAssetInner class.
+ */
+ public DiscoveredAssetInner() {
+ }
+
+ /**
+ * Get the properties property: The resource-specific properties for this resource.
+ *
+ * @return the properties value.
+ */
+ public DiscoveredAssetProperties properties() {
+ return this.properties;
+ }
+
+ /**
+ * Set the properties property: The resource-specific properties for this resource.
+ *
+ * @param properties the properties value to set.
+ * @return the DiscoveredAssetInner object itself.
+ */
+ public DiscoveredAssetInner withProperties(DiscoveredAssetProperties properties) {
+ this.properties = properties;
+ return this;
+ }
+
+ /**
+ * Get the extendedLocation property: The extended location.
+ *
+ * @return the extendedLocation value.
+ */
+ public ExtendedLocation extendedLocation() {
+ return this.extendedLocation;
+ }
+
+ /**
+ * Set the extendedLocation property: The extended location.
+ *
+ * @param extendedLocation the extendedLocation value to set.
+ * @return the DiscoveredAssetInner object itself.
+ */
+ public DiscoveredAssetInner withExtendedLocation(ExtendedLocation extendedLocation) {
+ this.extendedLocation = extendedLocation;
+ return this;
+ }
+
+ /**
+ * Get the systemData property: Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ *
+ * @return the systemData value.
+ */
+ public SystemData systemData() {
+ return this.systemData;
+ }
+
+ /**
+ * Get the type property: The type of the resource.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Get the name property: The name of the resource.
+ *
+ * @return the name value.
+ */
+ @Override
+ public String name() {
+ return this.name;
+ }
+
+ /**
+ * Get the id property: Fully qualified resource Id for the resource.
+ *
+ * @return the id value.
+ */
+ @Override
+ public String id() {
+ return this.id;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public DiscoveredAssetInner withLocation(String location) {
+ super.withLocation(location);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public DiscoveredAssetInner withTags(Map tags) {
+ super.withTags(tags);
+ return this;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ public void validate() {
+ if (properties() != null) {
+ properties().validate();
+ }
+ if (extendedLocation() == null) {
+ throw LOGGER.atError()
+ .log(new IllegalArgumentException(
+ "Missing required property extendedLocation in model DiscoveredAssetInner"));
+ } else {
+ extendedLocation().validate();
+ }
+ }
+
+ private static final ClientLogger LOGGER = new ClientLogger(DiscoveredAssetInner.class);
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeStringField("location", location());
+ jsonWriter.writeMapField("tags", tags(), (writer, element) -> writer.writeString(element));
+ jsonWriter.writeJsonField("extendedLocation", this.extendedLocation);
+ jsonWriter.writeJsonField("properties", this.properties);
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of DiscoveredAssetInner from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of DiscoveredAssetInner if the JsonReader was pointing to an instance of it, or null if it
+ * was pointing to JSON null.
+ * @throws IllegalStateException If the deserialized JSON object was missing any required properties.
+ * @throws IOException If an error occurs while reading the DiscoveredAssetInner.
+ */
+ public static DiscoveredAssetInner fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ DiscoveredAssetInner deserializedDiscoveredAssetInner = new DiscoveredAssetInner();
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("id".equals(fieldName)) {
+ deserializedDiscoveredAssetInner.id = reader.getString();
+ } else if ("name".equals(fieldName)) {
+ deserializedDiscoveredAssetInner.name = reader.getString();
+ } else if ("type".equals(fieldName)) {
+ deserializedDiscoveredAssetInner.type = reader.getString();
+ } else if ("location".equals(fieldName)) {
+ deserializedDiscoveredAssetInner.withLocation(reader.getString());
+ } else if ("tags".equals(fieldName)) {
+ Map tags = reader.readMap(reader1 -> reader1.getString());
+ deserializedDiscoveredAssetInner.withTags(tags);
+ } else if ("extendedLocation".equals(fieldName)) {
+ deserializedDiscoveredAssetInner.extendedLocation = ExtendedLocation.fromJson(reader);
+ } else if ("properties".equals(fieldName)) {
+ deserializedDiscoveredAssetInner.properties = DiscoveredAssetProperties.fromJson(reader);
+ } else if ("systemData".equals(fieldName)) {
+ deserializedDiscoveredAssetInner.systemData = SystemData.fromJson(reader);
+ } else {
+ reader.skipChildren();
+ }
+ }
+
+ return deserializedDiscoveredAssetInner;
+ });
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/OperationStatusResultInner.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/OperationStatusResultInner.java
index ef72a93767df..28ead9d57175 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/OperationStatusResultInner.java
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/OperationStatusResultInner.java
@@ -62,6 +62,11 @@ public final class OperationStatusResultInner implements JsonSerializable {
+ SchemaInner deserializedSchemaInner = new SchemaInner();
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("id".equals(fieldName)) {
+ deserializedSchemaInner.id = reader.getString();
+ } else if ("name".equals(fieldName)) {
+ deserializedSchemaInner.name = reader.getString();
+ } else if ("type".equals(fieldName)) {
+ deserializedSchemaInner.type = reader.getString();
+ } else if ("properties".equals(fieldName)) {
+ deserializedSchemaInner.properties = SchemaProperties.fromJson(reader);
+ } else if ("systemData".equals(fieldName)) {
+ deserializedSchemaInner.systemData = SystemData.fromJson(reader);
+ } else {
+ reader.skipChildren();
+ }
+ }
+
+ return deserializedSchemaInner;
+ });
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/SchemaRegistryInner.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/SchemaRegistryInner.java
new file mode 100644
index 000000000000..8abb1090dddc
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/SchemaRegistryInner.java
@@ -0,0 +1,224 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent.models;
+
+import com.azure.core.annotation.Fluent;
+import com.azure.core.management.Resource;
+import com.azure.core.management.SystemData;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import com.azure.resourcemanager.deviceregistry.models.SchemaRegistryProperties;
+import com.azure.resourcemanager.deviceregistry.models.SystemAssignedServiceIdentity;
+import java.io.IOException;
+import java.util.Map;
+
+/**
+ * Schema registry definition.
+ */
+@Fluent
+public final class SchemaRegistryInner extends Resource {
+ /*
+ * The resource-specific properties for this resource.
+ */
+ private SchemaRegistryProperties properties;
+
+ /*
+ * The managed service identities assigned to this resource.
+ */
+ private SystemAssignedServiceIdentity identity;
+
+ /*
+ * Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ */
+ private SystemData systemData;
+
+ /*
+ * The type of the resource.
+ */
+ private String type;
+
+ /*
+ * The name of the resource.
+ */
+ private String name;
+
+ /*
+ * Fully qualified resource Id for the resource.
+ */
+ private String id;
+
+ /**
+ * Creates an instance of SchemaRegistryInner class.
+ */
+ public SchemaRegistryInner() {
+ }
+
+ /**
+ * Get the properties property: The resource-specific properties for this resource.
+ *
+ * @return the properties value.
+ */
+ public SchemaRegistryProperties properties() {
+ return this.properties;
+ }
+
+ /**
+ * Set the properties property: The resource-specific properties for this resource.
+ *
+ * @param properties the properties value to set.
+ * @return the SchemaRegistryInner object itself.
+ */
+ public SchemaRegistryInner withProperties(SchemaRegistryProperties properties) {
+ this.properties = properties;
+ return this;
+ }
+
+ /**
+ * Get the identity property: The managed service identities assigned to this resource.
+ *
+ * @return the identity value.
+ */
+ public SystemAssignedServiceIdentity identity() {
+ return this.identity;
+ }
+
+ /**
+ * Set the identity property: The managed service identities assigned to this resource.
+ *
+ * @param identity the identity value to set.
+ * @return the SchemaRegistryInner object itself.
+ */
+ public SchemaRegistryInner withIdentity(SystemAssignedServiceIdentity identity) {
+ this.identity = identity;
+ return this;
+ }
+
+ /**
+ * Get the systemData property: Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ *
+ * @return the systemData value.
+ */
+ public SystemData systemData() {
+ return this.systemData;
+ }
+
+ /**
+ * Get the type property: The type of the resource.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Get the name property: The name of the resource.
+ *
+ * @return the name value.
+ */
+ @Override
+ public String name() {
+ return this.name;
+ }
+
+ /**
+ * Get the id property: Fully qualified resource Id for the resource.
+ *
+ * @return the id value.
+ */
+ @Override
+ public String id() {
+ return this.id;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public SchemaRegistryInner withLocation(String location) {
+ super.withLocation(location);
+ return this;
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public SchemaRegistryInner withTags(Map tags) {
+ super.withTags(tags);
+ return this;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ public void validate() {
+ if (properties() != null) {
+ properties().validate();
+ }
+ if (identity() != null) {
+ identity().validate();
+ }
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeStringField("location", location());
+ jsonWriter.writeMapField("tags", tags(), (writer, element) -> writer.writeString(element));
+ jsonWriter.writeJsonField("properties", this.properties);
+ jsonWriter.writeJsonField("identity", this.identity);
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of SchemaRegistryInner from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of SchemaRegistryInner if the JsonReader was pointing to an instance of it, or null if it was
+ * pointing to JSON null.
+ * @throws IllegalStateException If the deserialized JSON object was missing any required properties.
+ * @throws IOException If an error occurs while reading the SchemaRegistryInner.
+ */
+ public static SchemaRegistryInner fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ SchemaRegistryInner deserializedSchemaRegistryInner = new SchemaRegistryInner();
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("id".equals(fieldName)) {
+ deserializedSchemaRegistryInner.id = reader.getString();
+ } else if ("name".equals(fieldName)) {
+ deserializedSchemaRegistryInner.name = reader.getString();
+ } else if ("type".equals(fieldName)) {
+ deserializedSchemaRegistryInner.type = reader.getString();
+ } else if ("location".equals(fieldName)) {
+ deserializedSchemaRegistryInner.withLocation(reader.getString());
+ } else if ("tags".equals(fieldName)) {
+ Map tags = reader.readMap(reader1 -> reader1.getString());
+ deserializedSchemaRegistryInner.withTags(tags);
+ } else if ("properties".equals(fieldName)) {
+ deserializedSchemaRegistryInner.properties = SchemaRegistryProperties.fromJson(reader);
+ } else if ("identity".equals(fieldName)) {
+ deserializedSchemaRegistryInner.identity = SystemAssignedServiceIdentity.fromJson(reader);
+ } else if ("systemData".equals(fieldName)) {
+ deserializedSchemaRegistryInner.systemData = SystemData.fromJson(reader);
+ } else {
+ reader.skipChildren();
+ }
+ }
+
+ return deserializedSchemaRegistryInner;
+ });
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/SchemaVersionInner.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/SchemaVersionInner.java
new file mode 100644
index 000000000000..9c234ec7f0c8
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/fluent/models/SchemaVersionInner.java
@@ -0,0 +1,166 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.fluent.models;
+
+import com.azure.core.annotation.Fluent;
+import com.azure.core.management.ProxyResource;
+import com.azure.core.management.SystemData;
+import com.azure.json.JsonReader;
+import com.azure.json.JsonToken;
+import com.azure.json.JsonWriter;
+import com.azure.resourcemanager.deviceregistry.models.SchemaVersionProperties;
+import java.io.IOException;
+
+/**
+ * Schema version's definition.
+ */
+@Fluent
+public final class SchemaVersionInner extends ProxyResource {
+ /*
+ * The resource-specific properties for this resource.
+ */
+ private SchemaVersionProperties properties;
+
+ /*
+ * Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ */
+ private SystemData systemData;
+
+ /*
+ * The type of the resource.
+ */
+ private String type;
+
+ /*
+ * The name of the resource.
+ */
+ private String name;
+
+ /*
+ * Fully qualified resource Id for the resource.
+ */
+ private String id;
+
+ /**
+ * Creates an instance of SchemaVersionInner class.
+ */
+ public SchemaVersionInner() {
+ }
+
+ /**
+ * Get the properties property: The resource-specific properties for this resource.
+ *
+ * @return the properties value.
+ */
+ public SchemaVersionProperties properties() {
+ return this.properties;
+ }
+
+ /**
+ * Set the properties property: The resource-specific properties for this resource.
+ *
+ * @param properties the properties value to set.
+ * @return the SchemaVersionInner object itself.
+ */
+ public SchemaVersionInner withProperties(SchemaVersionProperties properties) {
+ this.properties = properties;
+ return this;
+ }
+
+ /**
+ * Get the systemData property: Azure Resource Manager metadata containing createdBy and modifiedBy information.
+ *
+ * @return the systemData value.
+ */
+ public SystemData systemData() {
+ return this.systemData;
+ }
+
+ /**
+ * Get the type property: The type of the resource.
+ *
+ * @return the type value.
+ */
+ @Override
+ public String type() {
+ return this.type;
+ }
+
+ /**
+ * Get the name property: The name of the resource.
+ *
+ * @return the name value.
+ */
+ @Override
+ public String name() {
+ return this.name;
+ }
+
+ /**
+ * Get the id property: Fully qualified resource Id for the resource.
+ *
+ * @return the id value.
+ */
+ @Override
+ public String id() {
+ return this.id;
+ }
+
+ /**
+ * Validates the instance.
+ *
+ * @throws IllegalArgumentException thrown if the instance is not valid.
+ */
+ public void validate() {
+ if (properties() != null) {
+ properties().validate();
+ }
+ }
+
+ /**
+ * {@inheritDoc}
+ */
+ @Override
+ public JsonWriter toJson(JsonWriter jsonWriter) throws IOException {
+ jsonWriter.writeStartObject();
+ jsonWriter.writeJsonField("properties", this.properties);
+ return jsonWriter.writeEndObject();
+ }
+
+ /**
+ * Reads an instance of SchemaVersionInner from the JsonReader.
+ *
+ * @param jsonReader The JsonReader being read.
+ * @return An instance of SchemaVersionInner if the JsonReader was pointing to an instance of it, or null if it was
+ * pointing to JSON null.
+ * @throws IllegalStateException If the deserialized JSON object was missing any required properties.
+ * @throws IOException If an error occurs while reading the SchemaVersionInner.
+ */
+ public static SchemaVersionInner fromJson(JsonReader jsonReader) throws IOException {
+ return jsonReader.readObject(reader -> {
+ SchemaVersionInner deserializedSchemaVersionInner = new SchemaVersionInner();
+ while (reader.nextToken() != JsonToken.END_OBJECT) {
+ String fieldName = reader.getFieldName();
+ reader.nextToken();
+
+ if ("id".equals(fieldName)) {
+ deserializedSchemaVersionInner.id = reader.getString();
+ } else if ("name".equals(fieldName)) {
+ deserializedSchemaVersionInner.name = reader.getString();
+ } else if ("type".equals(fieldName)) {
+ deserializedSchemaVersionInner.type = reader.getString();
+ } else if ("properties".equals(fieldName)) {
+ deserializedSchemaVersionInner.properties = SchemaVersionProperties.fromJson(reader);
+ } else if ("systemData".equals(fieldName)) {
+ deserializedSchemaVersionInner.systemData = SystemData.fromJson(reader);
+ } else {
+ reader.skipChildren();
+ }
+ }
+
+ return deserializedSchemaVersionInner;
+ });
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetEndpointProfilesClientImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetEndpointProfilesClientImpl.java
index 67aabbbfc96b..28ee7da06f69 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetEndpointProfilesClientImpl.java
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetEndpointProfilesClientImpl.java
@@ -52,25 +52,25 @@ public final class AssetEndpointProfilesClientImpl implements AssetEndpointProfi
/**
* The service client containing this operation class.
*/
- private final DeviceRegistryClientImpl client;
+ private final DeviceRegistryManagementClientImpl client;
/**
* Initializes an instance of AssetEndpointProfilesClientImpl.
*
* @param client the instance of the service client containing this operation class.
*/
- AssetEndpointProfilesClientImpl(DeviceRegistryClientImpl client) {
+ AssetEndpointProfilesClientImpl(DeviceRegistryManagementClientImpl client) {
this.service = RestProxy.create(AssetEndpointProfilesService.class, client.getHttpPipeline(),
client.getSerializerAdapter());
this.client = client;
}
/**
- * The interface defining all the services for DeviceRegistryClientAssetEndpointProfiles to be used by the proxy
- * service to perform REST calls.
+ * The interface defining all the services for DeviceRegistryManagementClientAssetEndpointProfiles to be used by the
+ * proxy service to perform REST calls.
*/
@Host("{endpoint}")
- @ServiceInterface(name = "DeviceRegistryClient")
+ @ServiceInterface(name = "DeviceRegistryManage")
public interface AssetEndpointProfilesService {
@Headers({ "Content-Type: application/json" })
@Get("/subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/Microsoft.DeviceRegistry/assetEndpointProfiles/{assetEndpointProfileName}")
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetsClientImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetsClientImpl.java
index beae8f67435c..793a5c2ae793 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetsClientImpl.java
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/AssetsClientImpl.java
@@ -52,24 +52,24 @@ public final class AssetsClientImpl implements AssetsClient {
/**
* The service client containing this operation class.
*/
- private final DeviceRegistryClientImpl client;
+ private final DeviceRegistryManagementClientImpl client;
/**
* Initializes an instance of AssetsClientImpl.
*
* @param client the instance of the service client containing this operation class.
*/
- AssetsClientImpl(DeviceRegistryClientImpl client) {
+ AssetsClientImpl(DeviceRegistryManagementClientImpl client) {
this.service = RestProxy.create(AssetsService.class, client.getHttpPipeline(), client.getSerializerAdapter());
this.client = client;
}
/**
- * The interface defining all the services for DeviceRegistryClientAssets to be used by the proxy service to perform
- * REST calls.
+ * The interface defining all the services for DeviceRegistryManagementClientAssets to be used by the proxy service
+ * to perform REST calls.
*/
@Host("{endpoint}")
- @ServiceInterface(name = "DeviceRegistryClient")
+ @ServiceInterface(name = "DeviceRegistryManage")
public interface AssetsService {
@Headers({ "Content-Type: application/json" })
@Get("/subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/Microsoft.DeviceRegistry/assets/{assetName}")
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainerImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainerImpl.java
new file mode 100644
index 000000000000..553aa10e8b3a
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainerImpl.java
@@ -0,0 +1,54 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.implementation;
+
+import com.azure.core.management.SystemData;
+import com.azure.resourcemanager.deviceregistry.fluent.models.BillingContainerInner;
+import com.azure.resourcemanager.deviceregistry.models.BillingContainer;
+import com.azure.resourcemanager.deviceregistry.models.BillingContainerProperties;
+
+public final class BillingContainerImpl implements BillingContainer {
+ private BillingContainerInner innerObject;
+
+ private final com.azure.resourcemanager.deviceregistry.DeviceRegistryManager serviceManager;
+
+ BillingContainerImpl(BillingContainerInner innerObject,
+ com.azure.resourcemanager.deviceregistry.DeviceRegistryManager serviceManager) {
+ this.innerObject = innerObject;
+ this.serviceManager = serviceManager;
+ }
+
+ public String id() {
+ return this.innerModel().id();
+ }
+
+ public String name() {
+ return this.innerModel().name();
+ }
+
+ public String type() {
+ return this.innerModel().type();
+ }
+
+ public BillingContainerProperties properties() {
+ return this.innerModel().properties();
+ }
+
+ public String etag() {
+ return this.innerModel().etag();
+ }
+
+ public SystemData systemData() {
+ return this.innerModel().systemData();
+ }
+
+ public BillingContainerInner innerModel() {
+ return this.innerObject;
+ }
+
+ private com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager() {
+ return this.serviceManager;
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainersClientImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainersClientImpl.java
new file mode 100644
index 000000000000..518d55d7ee97
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainersClientImpl.java
@@ -0,0 +1,359 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.implementation;
+
+import com.azure.core.annotation.ExpectedResponses;
+import com.azure.core.annotation.Get;
+import com.azure.core.annotation.HeaderParam;
+import com.azure.core.annotation.Headers;
+import com.azure.core.annotation.Host;
+import com.azure.core.annotation.HostParam;
+import com.azure.core.annotation.PathParam;
+import com.azure.core.annotation.QueryParam;
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceInterface;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.annotation.UnexpectedResponseExceptionType;
+import com.azure.core.http.rest.PagedFlux;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.PagedResponse;
+import com.azure.core.http.rest.PagedResponseBase;
+import com.azure.core.http.rest.Response;
+import com.azure.core.http.rest.RestProxy;
+import com.azure.core.management.exception.ManagementException;
+import com.azure.core.util.Context;
+import com.azure.core.util.FluxUtil;
+import com.azure.resourcemanager.deviceregistry.fluent.BillingContainersClient;
+import com.azure.resourcemanager.deviceregistry.fluent.models.BillingContainerInner;
+import com.azure.resourcemanager.deviceregistry.implementation.models.BillingContainerListResult;
+import reactor.core.publisher.Mono;
+
+/**
+ * An instance of this class provides access to all the operations defined in BillingContainersClient.
+ */
+public final class BillingContainersClientImpl implements BillingContainersClient {
+ /**
+ * The proxy service used to perform REST calls.
+ */
+ private final BillingContainersService service;
+
+ /**
+ * The service client containing this operation class.
+ */
+ private final DeviceRegistryManagementClientImpl client;
+
+ /**
+ * Initializes an instance of BillingContainersClientImpl.
+ *
+ * @param client the instance of the service client containing this operation class.
+ */
+ BillingContainersClientImpl(DeviceRegistryManagementClientImpl client) {
+ this.service
+ = RestProxy.create(BillingContainersService.class, client.getHttpPipeline(), client.getSerializerAdapter());
+ this.client = client;
+ }
+
+ /**
+ * The interface defining all the services for DeviceRegistryManagementClientBillingContainers to be used by the
+ * proxy service to perform REST calls.
+ */
+ @Host("{endpoint}")
+ @ServiceInterface(name = "DeviceRegistryManage")
+ public interface BillingContainersService {
+ @Headers({ "Content-Type: application/json" })
+ @Get("/subscriptions/{subscriptionId}/providers/Microsoft.DeviceRegistry/billingContainers/{billingContainerName}")
+ @ExpectedResponses({ 200 })
+ @UnexpectedResponseExceptionType(ManagementException.class)
+ Mono> get(@HostParam("endpoint") String endpoint,
+ @QueryParam("api-version") String apiVersion, @PathParam("subscriptionId") String subscriptionId,
+ @PathParam("billingContainerName") String billingContainerName, @HeaderParam("Accept") String accept,
+ Context context);
+
+ @Headers({ "Content-Type: application/json" })
+ @Get("/subscriptions/{subscriptionId}/providers/Microsoft.DeviceRegistry/billingContainers")
+ @ExpectedResponses({ 200 })
+ @UnexpectedResponseExceptionType(ManagementException.class)
+ Mono> list(@HostParam("endpoint") String endpoint,
+ @QueryParam("api-version") String apiVersion, @PathParam("subscriptionId") String subscriptionId,
+ @HeaderParam("Accept") String accept, Context context);
+
+ @Headers({ "Content-Type: application/json" })
+ @Get("{nextLink}")
+ @ExpectedResponses({ 200 })
+ @UnexpectedResponseExceptionType(ManagementException.class)
+ Mono> listBySubscriptionNext(
+ @PathParam(value = "nextLink", encoded = true) String nextLink, @HostParam("endpoint") String endpoint,
+ @HeaderParam("Accept") String accept, Context context);
+ }
+
+ /**
+ * Get a BillingContainer.
+ *
+ * @param billingContainerName Name of the billing container.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a BillingContainer along with {@link Response} on successful completion of {@link Mono}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ private Mono> getWithResponseAsync(String billingContainerName) {
+ if (this.client.getEndpoint() == null) {
+ return Mono.error(
+ new IllegalArgumentException("Parameter this.client.getEndpoint() is required and cannot be null."));
+ }
+ if (this.client.getSubscriptionId() == null) {
+ return Mono.error(new IllegalArgumentException(
+ "Parameter this.client.getSubscriptionId() is required and cannot be null."));
+ }
+ if (billingContainerName == null) {
+ return Mono
+ .error(new IllegalArgumentException("Parameter billingContainerName is required and cannot be null."));
+ }
+ final String accept = "application/json";
+ return FluxUtil
+ .withContext(context -> service.get(this.client.getEndpoint(), this.client.getApiVersion(),
+ this.client.getSubscriptionId(), billingContainerName, accept, context))
+ .contextWrite(context -> context.putAll(FluxUtil.toReactorContext(this.client.getContext()).readOnly()));
+ }
+
+ /**
+ * Get a BillingContainer.
+ *
+ * @param billingContainerName Name of the billing container.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a BillingContainer along with {@link Response} on successful completion of {@link Mono}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ private Mono> getWithResponseAsync(String billingContainerName, Context context) {
+ if (this.client.getEndpoint() == null) {
+ return Mono.error(
+ new IllegalArgumentException("Parameter this.client.getEndpoint() is required and cannot be null."));
+ }
+ if (this.client.getSubscriptionId() == null) {
+ return Mono.error(new IllegalArgumentException(
+ "Parameter this.client.getSubscriptionId() is required and cannot be null."));
+ }
+ if (billingContainerName == null) {
+ return Mono
+ .error(new IllegalArgumentException("Parameter billingContainerName is required and cannot be null."));
+ }
+ final String accept = "application/json";
+ context = this.client.mergeContext(context);
+ return service.get(this.client.getEndpoint(), this.client.getApiVersion(), this.client.getSubscriptionId(),
+ billingContainerName, accept, context);
+ }
+
+ /**
+ * Get a BillingContainer.
+ *
+ * @param billingContainerName Name of the billing container.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a BillingContainer on successful completion of {@link Mono}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ private Mono getAsync(String billingContainerName) {
+ return getWithResponseAsync(billingContainerName).flatMap(res -> Mono.justOrEmpty(res.getValue()));
+ }
+
+ /**
+ * Get a BillingContainer.
+ *
+ * @param billingContainerName Name of the billing container.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a BillingContainer along with {@link Response}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ public Response getWithResponse(String billingContainerName, Context context) {
+ return getWithResponseAsync(billingContainerName, context).block();
+ }
+
+ /**
+ * Get a BillingContainer.
+ *
+ * @param billingContainerName Name of the billing container.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return a BillingContainer.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ public BillingContainerInner get(String billingContainerName) {
+ return getWithResponse(billingContainerName, Context.NONE).getValue();
+ }
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation along with {@link PagedResponse} on successful
+ * completion of {@link Mono}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ private Mono> listSinglePageAsync() {
+ if (this.client.getEndpoint() == null) {
+ return Mono.error(
+ new IllegalArgumentException("Parameter this.client.getEndpoint() is required and cannot be null."));
+ }
+ if (this.client.getSubscriptionId() == null) {
+ return Mono.error(new IllegalArgumentException(
+ "Parameter this.client.getSubscriptionId() is required and cannot be null."));
+ }
+ final String accept = "application/json";
+ return FluxUtil
+ .withContext(context -> service.list(this.client.getEndpoint(), this.client.getApiVersion(),
+ this.client.getSubscriptionId(), accept, context))
+ .>map(res -> new PagedResponseBase<>(res.getRequest(),
+ res.getStatusCode(), res.getHeaders(), res.getValue().value(), res.getValue().nextLink(), null))
+ .contextWrite(context -> context.putAll(FluxUtil.toReactorContext(this.client.getContext()).readOnly()));
+ }
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation along with {@link PagedResponse} on successful
+ * completion of {@link Mono}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ private Mono> listSinglePageAsync(Context context) {
+ if (this.client.getEndpoint() == null) {
+ return Mono.error(
+ new IllegalArgumentException("Parameter this.client.getEndpoint() is required and cannot be null."));
+ }
+ if (this.client.getSubscriptionId() == null) {
+ return Mono.error(new IllegalArgumentException(
+ "Parameter this.client.getSubscriptionId() is required and cannot be null."));
+ }
+ final String accept = "application/json";
+ context = this.client.mergeContext(context);
+ return service
+ .list(this.client.getEndpoint(), this.client.getApiVersion(), this.client.getSubscriptionId(), accept,
+ context)
+ .map(res -> new PagedResponseBase<>(res.getRequest(), res.getStatusCode(), res.getHeaders(),
+ res.getValue().value(), res.getValue().nextLink(), null));
+ }
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation as paginated response with {@link PagedFlux}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ private PagedFlux listAsync() {
+ return new PagedFlux<>(() -> listSinglePageAsync(),
+ nextLink -> listBySubscriptionNextSinglePageAsync(nextLink));
+ }
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation as paginated response with {@link PagedFlux}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ private PagedFlux listAsync(Context context) {
+ return new PagedFlux<>(() -> listSinglePageAsync(context),
+ nextLink -> listBySubscriptionNextSinglePageAsync(nextLink, context));
+ }
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ public PagedIterable list() {
+ return new PagedIterable<>(listAsync());
+ }
+
+ /**
+ * List BillingContainer resources by subscription ID.
+ *
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation as paginated response with {@link PagedIterable}.
+ */
+ @ServiceMethod(returns = ReturnType.COLLECTION)
+ public PagedIterable list(Context context) {
+ return new PagedIterable<>(listAsync(context));
+ }
+
+ /**
+ * Get the next page of items.
+ *
+ * @param nextLink The URL to get the next list of items.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation along with {@link PagedResponse} on successful
+ * completion of {@link Mono}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ private Mono> listBySubscriptionNextSinglePageAsync(String nextLink) {
+ if (nextLink == null) {
+ return Mono.error(new IllegalArgumentException("Parameter nextLink is required and cannot be null."));
+ }
+ if (this.client.getEndpoint() == null) {
+ return Mono.error(
+ new IllegalArgumentException("Parameter this.client.getEndpoint() is required and cannot be null."));
+ }
+ final String accept = "application/json";
+ return FluxUtil
+ .withContext(
+ context -> service.listBySubscriptionNext(nextLink, this.client.getEndpoint(), accept, context))
+ .>map(res -> new PagedResponseBase<>(res.getRequest(),
+ res.getStatusCode(), res.getHeaders(), res.getValue().value(), res.getValue().nextLink(), null))
+ .contextWrite(context -> context.putAll(FluxUtil.toReactorContext(this.client.getContext()).readOnly()));
+ }
+
+ /**
+ * Get the next page of items.
+ *
+ * @param nextLink The URL to get the next list of items.
+ * @param context The context to associate with this operation.
+ * @throws IllegalArgumentException thrown if parameters fail the validation.
+ * @throws ManagementException thrown if the request is rejected by server.
+ * @throws RuntimeException all other wrapped checked exceptions if the request fails to be sent.
+ * @return the response of a BillingContainer list operation along with {@link PagedResponse} on successful
+ * completion of {@link Mono}.
+ */
+ @ServiceMethod(returns = ReturnType.SINGLE)
+ private Mono> listBySubscriptionNextSinglePageAsync(String nextLink,
+ Context context) {
+ if (nextLink == null) {
+ return Mono.error(new IllegalArgumentException("Parameter nextLink is required and cannot be null."));
+ }
+ if (this.client.getEndpoint() == null) {
+ return Mono.error(
+ new IllegalArgumentException("Parameter this.client.getEndpoint() is required and cannot be null."));
+ }
+ final String accept = "application/json";
+ context = this.client.mergeContext(context);
+ return service.listBySubscriptionNext(nextLink, this.client.getEndpoint(), accept, context)
+ .map(res -> new PagedResponseBase<>(res.getRequest(), res.getStatusCode(), res.getHeaders(),
+ res.getValue().value(), res.getValue().nextLink(), null));
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainersImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainersImpl.java
new file mode 100644
index 000000000000..5ba318e04334
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/BillingContainersImpl.java
@@ -0,0 +1,66 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.implementation;
+
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.Response;
+import com.azure.core.http.rest.SimpleResponse;
+import com.azure.core.util.Context;
+import com.azure.core.util.logging.ClientLogger;
+import com.azure.resourcemanager.deviceregistry.fluent.BillingContainersClient;
+import com.azure.resourcemanager.deviceregistry.fluent.models.BillingContainerInner;
+import com.azure.resourcemanager.deviceregistry.models.BillingContainer;
+import com.azure.resourcemanager.deviceregistry.models.BillingContainers;
+
+public final class BillingContainersImpl implements BillingContainers {
+ private static final ClientLogger LOGGER = new ClientLogger(BillingContainersImpl.class);
+
+ private final BillingContainersClient innerClient;
+
+ private final com.azure.resourcemanager.deviceregistry.DeviceRegistryManager serviceManager;
+
+ public BillingContainersImpl(BillingContainersClient innerClient,
+ com.azure.resourcemanager.deviceregistry.DeviceRegistryManager serviceManager) {
+ this.innerClient = innerClient;
+ this.serviceManager = serviceManager;
+ }
+
+ public Response getWithResponse(String billingContainerName, Context context) {
+ Response inner = this.serviceClient().getWithResponse(billingContainerName, context);
+ if (inner != null) {
+ return new SimpleResponse<>(inner.getRequest(), inner.getStatusCode(), inner.getHeaders(),
+ new BillingContainerImpl(inner.getValue(), this.manager()));
+ } else {
+ return null;
+ }
+ }
+
+ public BillingContainer get(String billingContainerName) {
+ BillingContainerInner inner = this.serviceClient().get(billingContainerName);
+ if (inner != null) {
+ return new BillingContainerImpl(inner, this.manager());
+ } else {
+ return null;
+ }
+ }
+
+ public PagedIterable list() {
+ PagedIterable inner = this.serviceClient().list();
+ return ResourceManagerUtils.mapPage(inner, inner1 -> new BillingContainerImpl(inner1, this.manager()));
+ }
+
+ public PagedIterable list(Context context) {
+ PagedIterable inner = this.serviceClient().list(context);
+ return ResourceManagerUtils.mapPage(inner, inner1 -> new BillingContainerImpl(inner1, this.manager()));
+ }
+
+ private BillingContainersClient serviceClient() {
+ return this.innerClient;
+ }
+
+ private com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager() {
+ return this.serviceManager;
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryClientBuilder.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryManagementClientBuilder.java
similarity index 67%
rename from sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryClientBuilder.java
rename to sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryManagementClientBuilder.java
index 54d34610039a..c6ed35c90e84 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryClientBuilder.java
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryManagementClientBuilder.java
@@ -15,10 +15,10 @@
import java.time.Duration;
/**
- * A builder for creating a new instance of the DeviceRegistryClientImpl type.
+ * A builder for creating a new instance of the DeviceRegistryManagementClientImpl type.
*/
-@ServiceClientBuilder(serviceClients = { DeviceRegistryClientImpl.class })
-public final class DeviceRegistryClientBuilder {
+@ServiceClientBuilder(serviceClients = { DeviceRegistryManagementClientImpl.class })
+public final class DeviceRegistryManagementClientBuilder {
/*
* Service host
*/
@@ -28,9 +28,9 @@ public final class DeviceRegistryClientBuilder {
* Sets Service host.
*
* @param endpoint the endpoint value.
- * @return the DeviceRegistryClientBuilder.
+ * @return the DeviceRegistryManagementClientBuilder.
*/
- public DeviceRegistryClientBuilder endpoint(String endpoint) {
+ public DeviceRegistryManagementClientBuilder endpoint(String endpoint) {
this.endpoint = endpoint;
return this;
}
@@ -44,9 +44,9 @@ public DeviceRegistryClientBuilder endpoint(String endpoint) {
* Sets The ID of the target subscription. The value must be an UUID.
*
* @param subscriptionId the subscriptionId value.
- * @return the DeviceRegistryClientBuilder.
+ * @return the DeviceRegistryManagementClientBuilder.
*/
- public DeviceRegistryClientBuilder subscriptionId(String subscriptionId) {
+ public DeviceRegistryManagementClientBuilder subscriptionId(String subscriptionId) {
this.subscriptionId = subscriptionId;
return this;
}
@@ -60,9 +60,9 @@ public DeviceRegistryClientBuilder subscriptionId(String subscriptionId) {
* Sets The environment to connect to.
*
* @param environment the environment value.
- * @return the DeviceRegistryClientBuilder.
+ * @return the DeviceRegistryManagementClientBuilder.
*/
- public DeviceRegistryClientBuilder environment(AzureEnvironment environment) {
+ public DeviceRegistryManagementClientBuilder environment(AzureEnvironment environment) {
this.environment = environment;
return this;
}
@@ -76,9 +76,9 @@ public DeviceRegistryClientBuilder environment(AzureEnvironment environment) {
* Sets The HTTP pipeline to send requests through.
*
* @param pipeline the pipeline value.
- * @return the DeviceRegistryClientBuilder.
+ * @return the DeviceRegistryManagementClientBuilder.
*/
- public DeviceRegistryClientBuilder pipeline(HttpPipeline pipeline) {
+ public DeviceRegistryManagementClientBuilder pipeline(HttpPipeline pipeline) {
this.pipeline = pipeline;
return this;
}
@@ -92,9 +92,9 @@ public DeviceRegistryClientBuilder pipeline(HttpPipeline pipeline) {
* Sets The default poll interval for long-running operation.
*
* @param defaultPollInterval the defaultPollInterval value.
- * @return the DeviceRegistryClientBuilder.
+ * @return the DeviceRegistryManagementClientBuilder.
*/
- public DeviceRegistryClientBuilder defaultPollInterval(Duration defaultPollInterval) {
+ public DeviceRegistryManagementClientBuilder defaultPollInterval(Duration defaultPollInterval) {
this.defaultPollInterval = defaultPollInterval;
return this;
}
@@ -108,19 +108,19 @@ public DeviceRegistryClientBuilder defaultPollInterval(Duration defaultPollInter
* Sets The serializer to serialize an object into a string.
*
* @param serializerAdapter the serializerAdapter value.
- * @return the DeviceRegistryClientBuilder.
+ * @return the DeviceRegistryManagementClientBuilder.
*/
- public DeviceRegistryClientBuilder serializerAdapter(SerializerAdapter serializerAdapter) {
+ public DeviceRegistryManagementClientBuilder serializerAdapter(SerializerAdapter serializerAdapter) {
this.serializerAdapter = serializerAdapter;
return this;
}
/**
- * Builds an instance of DeviceRegistryClientImpl with the provided parameters.
+ * Builds an instance of DeviceRegistryManagementClientImpl with the provided parameters.
*
- * @return an instance of DeviceRegistryClientImpl.
+ * @return an instance of DeviceRegistryManagementClientImpl.
*/
- public DeviceRegistryClientImpl buildClient() {
+ public DeviceRegistryManagementClientImpl buildClient() {
String localEndpoint = (endpoint != null) ? endpoint : "https://management.azure.com";
AzureEnvironment localEnvironment = (environment != null) ? environment : AzureEnvironment.AZURE;
HttpPipeline localPipeline = (pipeline != null)
@@ -131,8 +131,8 @@ public DeviceRegistryClientImpl buildClient() {
SerializerAdapter localSerializerAdapter = (serializerAdapter != null)
? serializerAdapter
: SerializerFactory.createDefaultManagementSerializerAdapter();
- DeviceRegistryClientImpl client = new DeviceRegistryClientImpl(localPipeline, localSerializerAdapter,
- localDefaultPollInterval, localEnvironment, localEndpoint, this.subscriptionId);
+ DeviceRegistryManagementClientImpl client = new DeviceRegistryManagementClientImpl(localPipeline,
+ localSerializerAdapter, localDefaultPollInterval, localEnvironment, localEndpoint, this.subscriptionId);
return client;
}
}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryClientImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryManagementClientImpl.java
similarity index 74%
rename from sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryClientImpl.java
rename to sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryManagementClientImpl.java
index f5cab59fef74..9aa7a4bce55a 100644
--- a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryClientImpl.java
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DeviceRegistryManagementClientImpl.java
@@ -25,9 +25,15 @@
import com.azure.core.util.serializer.SerializerEncoding;
import com.azure.resourcemanager.deviceregistry.fluent.AssetEndpointProfilesClient;
import com.azure.resourcemanager.deviceregistry.fluent.AssetsClient;
-import com.azure.resourcemanager.deviceregistry.fluent.DeviceRegistryClient;
+import com.azure.resourcemanager.deviceregistry.fluent.BillingContainersClient;
+import com.azure.resourcemanager.deviceregistry.fluent.DeviceRegistryManagementClient;
+import com.azure.resourcemanager.deviceregistry.fluent.DiscoveredAssetEndpointProfilesClient;
+import com.azure.resourcemanager.deviceregistry.fluent.DiscoveredAssetsClient;
import com.azure.resourcemanager.deviceregistry.fluent.OperationStatusClient;
import com.azure.resourcemanager.deviceregistry.fluent.OperationsClient;
+import com.azure.resourcemanager.deviceregistry.fluent.SchemaRegistriesClient;
+import com.azure.resourcemanager.deviceregistry.fluent.SchemaVersionsClient;
+import com.azure.resourcemanager.deviceregistry.fluent.SchemasClient;
import java.io.IOException;
import java.lang.reflect.Type;
import java.nio.ByteBuffer;
@@ -38,10 +44,10 @@
import reactor.core.publisher.Mono;
/**
- * Initializes a new instance of the DeviceRegistryClientImpl type.
+ * Initializes a new instance of the DeviceRegistryManagementClientImpl type.
*/
-@ServiceClient(builder = DeviceRegistryClientBuilder.class)
-public final class DeviceRegistryClientImpl implements DeviceRegistryClient {
+@ServiceClient(builder = DeviceRegistryManagementClientBuilder.class)
+public final class DeviceRegistryManagementClientImpl implements DeviceRegistryManagementClient {
/**
* Service host.
*/
@@ -183,7 +189,91 @@ public AssetEndpointProfilesClient getAssetEndpointProfiles() {
}
/**
- * Initializes an instance of DeviceRegistryClient client.
+ * The BillingContainersClient object to access its operations.
+ */
+ private final BillingContainersClient billingContainers;
+
+ /**
+ * Gets the BillingContainersClient object to access its operations.
+ *
+ * @return the BillingContainersClient object.
+ */
+ public BillingContainersClient getBillingContainers() {
+ return this.billingContainers;
+ }
+
+ /**
+ * The DiscoveredAssetsClient object to access its operations.
+ */
+ private final DiscoveredAssetsClient discoveredAssets;
+
+ /**
+ * Gets the DiscoveredAssetsClient object to access its operations.
+ *
+ * @return the DiscoveredAssetsClient object.
+ */
+ public DiscoveredAssetsClient getDiscoveredAssets() {
+ return this.discoveredAssets;
+ }
+
+ /**
+ * The DiscoveredAssetEndpointProfilesClient object to access its operations.
+ */
+ private final DiscoveredAssetEndpointProfilesClient discoveredAssetEndpointProfiles;
+
+ /**
+ * Gets the DiscoveredAssetEndpointProfilesClient object to access its operations.
+ *
+ * @return the DiscoveredAssetEndpointProfilesClient object.
+ */
+ public DiscoveredAssetEndpointProfilesClient getDiscoveredAssetEndpointProfiles() {
+ return this.discoveredAssetEndpointProfiles;
+ }
+
+ /**
+ * The SchemaRegistriesClient object to access its operations.
+ */
+ private final SchemaRegistriesClient schemaRegistries;
+
+ /**
+ * Gets the SchemaRegistriesClient object to access its operations.
+ *
+ * @return the SchemaRegistriesClient object.
+ */
+ public SchemaRegistriesClient getSchemaRegistries() {
+ return this.schemaRegistries;
+ }
+
+ /**
+ * The SchemasClient object to access its operations.
+ */
+ private final SchemasClient schemas;
+
+ /**
+ * Gets the SchemasClient object to access its operations.
+ *
+ * @return the SchemasClient object.
+ */
+ public SchemasClient getSchemas() {
+ return this.schemas;
+ }
+
+ /**
+ * The SchemaVersionsClient object to access its operations.
+ */
+ private final SchemaVersionsClient schemaVersions;
+
+ /**
+ * Gets the SchemaVersionsClient object to access its operations.
+ *
+ * @return the SchemaVersionsClient object.
+ */
+ public SchemaVersionsClient getSchemaVersions() {
+ return this.schemaVersions;
+ }
+
+ /**
+ * Initializes an instance of DeviceRegistryManagementClient client.
*
* @param httpPipeline The HTTP pipeline to send requests through.
* @param serializerAdapter The serializer to serialize an object into a string.
@@ -192,18 +282,24 @@ public AssetEndpointProfilesClient getAssetEndpointProfiles() {
* @param endpoint Service host.
* @param subscriptionId The ID of the target subscription. The value must be an UUID.
*/
- DeviceRegistryClientImpl(HttpPipeline httpPipeline, SerializerAdapter serializerAdapter,
+ DeviceRegistryManagementClientImpl(HttpPipeline httpPipeline, SerializerAdapter serializerAdapter,
Duration defaultPollInterval, AzureEnvironment environment, String endpoint, String subscriptionId) {
this.httpPipeline = httpPipeline;
this.serializerAdapter = serializerAdapter;
this.defaultPollInterval = defaultPollInterval;
this.endpoint = endpoint;
this.subscriptionId = subscriptionId;
- this.apiVersion = "2023-11-01-preview";
+ this.apiVersion = "2024-09-01-preview";
this.operations = new OperationsClientImpl(this);
this.operationStatus = new OperationStatusClientImpl(this);
this.assets = new AssetsClientImpl(this);
this.assetEndpointProfiles = new AssetEndpointProfilesClientImpl(this);
+ this.billingContainers = new BillingContainersClientImpl(this);
+ this.discoveredAssets = new DiscoveredAssetsClientImpl(this);
+ this.discoveredAssetEndpointProfiles = new DiscoveredAssetEndpointProfilesClientImpl(this);
+ this.schemaRegistries = new SchemaRegistriesClientImpl(this);
+ this.schemas = new SchemasClientImpl(this);
+ this.schemaVersions = new SchemaVersionsClientImpl(this);
}
/**
@@ -332,5 +428,5 @@ public Mono getBodyAsString(Charset charset) {
}
}
- private static final ClientLogger LOGGER = new ClientLogger(DeviceRegistryClientImpl.class);
+ private static final ClientLogger LOGGER = new ClientLogger(DeviceRegistryManagementClientImpl.class);
}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DiscoveredAssetEndpointProfileImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DiscoveredAssetEndpointProfileImpl.java
new file mode 100644
index 000000000000..88b31fc2df85
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DiscoveredAssetEndpointProfileImpl.java
@@ -0,0 +1,197 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.implementation;
+
+import com.azure.core.management.Region;
+import com.azure.core.management.SystemData;
+import com.azure.core.util.Context;
+import com.azure.resourcemanager.deviceregistry.fluent.models.DiscoveredAssetEndpointProfileInner;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfile;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileProperties;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileUpdate;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileUpdateProperties;
+import com.azure.resourcemanager.deviceregistry.models.ExtendedLocation;
+import java.util.Collections;
+import java.util.Map;
+
+public final class DiscoveredAssetEndpointProfileImpl implements DiscoveredAssetEndpointProfile,
+ DiscoveredAssetEndpointProfile.Definition, DiscoveredAssetEndpointProfile.Update {
+ private DiscoveredAssetEndpointProfileInner innerObject;
+
+ private final com.azure.resourcemanager.deviceregistry.DeviceRegistryManager serviceManager;
+
+ public String id() {
+ return this.innerModel().id();
+ }
+
+ public String name() {
+ return this.innerModel().name();
+ }
+
+ public String type() {
+ return this.innerModel().type();
+ }
+
+ public String location() {
+ return this.innerModel().location();
+ }
+
+ public Map tags() {
+ Map inner = this.innerModel().tags();
+ if (inner != null) {
+ return Collections.unmodifiableMap(inner);
+ } else {
+ return Collections.emptyMap();
+ }
+ }
+
+ public DiscoveredAssetEndpointProfileProperties properties() {
+ return this.innerModel().properties();
+ }
+
+ public ExtendedLocation extendedLocation() {
+ return this.innerModel().extendedLocation();
+ }
+
+ public SystemData systemData() {
+ return this.innerModel().systemData();
+ }
+
+ public Region region() {
+ return Region.fromName(this.regionName());
+ }
+
+ public String regionName() {
+ return this.location();
+ }
+
+ public String resourceGroupName() {
+ return resourceGroupName;
+ }
+
+ public DiscoveredAssetEndpointProfileInner innerModel() {
+ return this.innerObject;
+ }
+
+ private com.azure.resourcemanager.deviceregistry.DeviceRegistryManager manager() {
+ return this.serviceManager;
+ }
+
+ private String resourceGroupName;
+
+ private String discoveredAssetEndpointProfileName;
+
+ private DiscoveredAssetEndpointProfileUpdate updateProperties;
+
+ public DiscoveredAssetEndpointProfileImpl withExistingResourceGroup(String resourceGroupName) {
+ this.resourceGroupName = resourceGroupName;
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfile create() {
+ this.innerObject = serviceManager.serviceClient()
+ .getDiscoveredAssetEndpointProfiles()
+ .createOrReplace(resourceGroupName, discoveredAssetEndpointProfileName, this.innerModel(), Context.NONE);
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfile create(Context context) {
+ this.innerObject = serviceManager.serviceClient()
+ .getDiscoveredAssetEndpointProfiles()
+ .createOrReplace(resourceGroupName, discoveredAssetEndpointProfileName, this.innerModel(), context);
+ return this;
+ }
+
+ DiscoveredAssetEndpointProfileImpl(String name,
+ com.azure.resourcemanager.deviceregistry.DeviceRegistryManager serviceManager) {
+ this.innerObject = new DiscoveredAssetEndpointProfileInner();
+ this.serviceManager = serviceManager;
+ this.discoveredAssetEndpointProfileName = name;
+ }
+
+ public DiscoveredAssetEndpointProfileImpl update() {
+ this.updateProperties = new DiscoveredAssetEndpointProfileUpdate();
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfile apply() {
+ this.innerObject = serviceManager.serviceClient()
+ .getDiscoveredAssetEndpointProfiles()
+ .update(resourceGroupName, discoveredAssetEndpointProfileName, updateProperties, Context.NONE);
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfile apply(Context context) {
+ this.innerObject = serviceManager.serviceClient()
+ .getDiscoveredAssetEndpointProfiles()
+ .update(resourceGroupName, discoveredAssetEndpointProfileName, updateProperties, context);
+ return this;
+ }
+
+ DiscoveredAssetEndpointProfileImpl(DiscoveredAssetEndpointProfileInner innerObject,
+ com.azure.resourcemanager.deviceregistry.DeviceRegistryManager serviceManager) {
+ this.innerObject = innerObject;
+ this.serviceManager = serviceManager;
+ this.resourceGroupName = ResourceManagerUtils.getValueFromIdByName(innerObject.id(), "resourceGroups");
+ this.discoveredAssetEndpointProfileName
+ = ResourceManagerUtils.getValueFromIdByName(innerObject.id(), "discoveredAssetEndpointProfiles");
+ }
+
+ public DiscoveredAssetEndpointProfile refresh() {
+ this.innerObject = serviceManager.serviceClient()
+ .getDiscoveredAssetEndpointProfiles()
+ .getByResourceGroupWithResponse(resourceGroupName, discoveredAssetEndpointProfileName, Context.NONE)
+ .getValue();
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfile refresh(Context context) {
+ this.innerObject = serviceManager.serviceClient()
+ .getDiscoveredAssetEndpointProfiles()
+ .getByResourceGroupWithResponse(resourceGroupName, discoveredAssetEndpointProfileName, context)
+ .getValue();
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfileImpl withRegion(Region location) {
+ this.innerModel().withLocation(location.toString());
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfileImpl withRegion(String location) {
+ this.innerModel().withLocation(location);
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfileImpl withExtendedLocation(ExtendedLocation extendedLocation) {
+ this.innerModel().withExtendedLocation(extendedLocation);
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfileImpl withTags(Map tags) {
+ if (isInCreateMode()) {
+ this.innerModel().withTags(tags);
+ return this;
+ } else {
+ this.updateProperties.withTags(tags);
+ return this;
+ }
+ }
+
+ public DiscoveredAssetEndpointProfileImpl withProperties(DiscoveredAssetEndpointProfileProperties properties) {
+ this.innerModel().withProperties(properties);
+ return this;
+ }
+
+ public DiscoveredAssetEndpointProfileImpl
+ withProperties(DiscoveredAssetEndpointProfileUpdateProperties properties) {
+ this.updateProperties.withProperties(properties);
+ return this;
+ }
+
+ private boolean isInCreateMode() {
+ return this.innerModel().id() == null;
+ }
+}
diff --git a/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DiscoveredAssetEndpointProfilesClientImpl.java b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DiscoveredAssetEndpointProfilesClientImpl.java
new file mode 100644
index 000000000000..0075dd1ba2ab
--- /dev/null
+++ b/sdk/deviceregistry/azure-resourcemanager-deviceregistry/src/main/java/com/azure/resourcemanager/deviceregistry/implementation/DiscoveredAssetEndpointProfilesClientImpl.java
@@ -0,0 +1,1337 @@
+// Copyright (c) Microsoft Corporation. All rights reserved.
+// Licensed under the MIT License.
+// Code generated by Microsoft (R) TypeSpec Code Generator.
+
+package com.azure.resourcemanager.deviceregistry.implementation;
+
+import com.azure.core.annotation.BodyParam;
+import com.azure.core.annotation.Delete;
+import com.azure.core.annotation.ExpectedResponses;
+import com.azure.core.annotation.Get;
+import com.azure.core.annotation.HeaderParam;
+import com.azure.core.annotation.Headers;
+import com.azure.core.annotation.Host;
+import com.azure.core.annotation.HostParam;
+import com.azure.core.annotation.Patch;
+import com.azure.core.annotation.PathParam;
+import com.azure.core.annotation.Put;
+import com.azure.core.annotation.QueryParam;
+import com.azure.core.annotation.ReturnType;
+import com.azure.core.annotation.ServiceInterface;
+import com.azure.core.annotation.ServiceMethod;
+import com.azure.core.annotation.UnexpectedResponseExceptionType;
+import com.azure.core.http.rest.PagedFlux;
+import com.azure.core.http.rest.PagedIterable;
+import com.azure.core.http.rest.PagedResponse;
+import com.azure.core.http.rest.PagedResponseBase;
+import com.azure.core.http.rest.Response;
+import com.azure.core.http.rest.RestProxy;
+import com.azure.core.management.exception.ManagementException;
+import com.azure.core.management.polling.PollResult;
+import com.azure.core.util.Context;
+import com.azure.core.util.FluxUtil;
+import com.azure.core.util.polling.PollerFlux;
+import com.azure.core.util.polling.SyncPoller;
+import com.azure.resourcemanager.deviceregistry.fluent.DiscoveredAssetEndpointProfilesClient;
+import com.azure.resourcemanager.deviceregistry.fluent.models.DiscoveredAssetEndpointProfileInner;
+import com.azure.resourcemanager.deviceregistry.implementation.models.DiscoveredAssetEndpointProfileListResult;
+import com.azure.resourcemanager.deviceregistry.models.DiscoveredAssetEndpointProfileUpdate;
+import java.nio.ByteBuffer;
+import reactor.core.publisher.Flux;
+import reactor.core.publisher.Mono;
+
+/**
+ * An instance of this class provides access to all the operations defined in DiscoveredAssetEndpointProfilesClient.
+ */
+public final class DiscoveredAssetEndpointProfilesClientImpl implements DiscoveredAssetEndpointProfilesClient {
+ /**
+ * The proxy service used to perform REST calls.
+ */
+ private final DiscoveredAssetEndpointProfilesService service;
+
+ /**
+ * The service client containing this operation class.
+ */
+ private final DeviceRegistryManagementClientImpl client;
+
+ /**
+ * Initializes an instance of DiscoveredAssetEndpointProfilesClientImpl.
+ *
+ * @param client the instance of the service client containing this operation class.
+ */
+ DiscoveredAssetEndpointProfilesClientImpl(DeviceRegistryManagementClientImpl client) {
+ this.service = RestProxy.create(DiscoveredAssetEndpointProfilesService.class, client.getHttpPipeline(),
+ client.getSerializerAdapter());
+ this.client = client;
+ }
+
+ /**
+ * The interface defining all the services for DeviceRegistryManagementClientDiscoveredAssetEndpointProfiles to be
+ * used by the proxy service to perform REST calls.
+ */
+ @Host("{endpoint}")
+ @ServiceInterface(name = "DeviceRegistryManage")
+ public interface DiscoveredAssetEndpointProfilesService {
+ @Headers({ "Content-Type: application/json" })
+ @Get("/subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/Microsoft.DeviceRegistry/discoveredAssetEndpointProfiles/{discoveredAssetEndpointProfileName}")
+ @ExpectedResponses({ 200 })
+ @UnexpectedResponseExceptionType(ManagementException.class)
+ Mono> getByResourceGroup(@HostParam("endpoint") String endpoint,
+ @QueryParam("api-version") String apiVersion, @PathParam("subscriptionId") String subscriptionId,
+ @PathParam("resourceGroupName") String resourceGroupName,
+ @PathParam("discoveredAssetEndpointProfileName") String discoveredAssetEndpointProfileName,
+ @HeaderParam("Accept") String accept, Context context);
+
+ @Put("/subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/Microsoft.DeviceRegistry/discoveredAssetEndpointProfiles/{discoveredAssetEndpointProfileName}")
+ @ExpectedResponses({ 200, 201 })
+ @UnexpectedResponseExceptionType(ManagementException.class)
+ Mono>> createOrReplace(@HostParam("endpoint") String endpoint,
+ @QueryParam("api-version") String apiVersion, @PathParam("subscriptionId") String subscriptionId,
+ @PathParam("resourceGroupName") String resourceGroupName,
+ @PathParam("discoveredAssetEndpointProfileName") String discoveredAssetEndpointProfileName,
+ @HeaderParam("Content-Type") String contentType, @HeaderParam("Accept") String accept,
+ @BodyParam("application/json") DiscoveredAssetEndpointProfileInner resource, Context context);
+
+ @Patch("/subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/Microsoft.DeviceRegistry/discoveredAssetEndpointProfiles/{discoveredAssetEndpointProfileName}")
+ @ExpectedResponses({ 200, 202 })
+ @UnexpectedResponseExceptionType(ManagementException.class)
+ Mono