All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.beam.sdk.io.snowflake.SnowflakePipelineOptions Maven / Gradle / Ivy

/*
 * Licensed to the Apache Software Foundation (ASF) under one
 * or more contributor license agreements.  See the NOTICE file
 * distributed with this work for additional information
 * regarding copyright ownership.  The ASF licenses this file
 * to you under the Apache License, Version 2.0 (the
 * "License"); you may not use this file except in compliance
 * with the License.  You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package org.apache.beam.sdk.io.snowflake;

import org.apache.beam.sdk.options.Default;
import org.apache.beam.sdk.options.Description;
import org.apache.beam.sdk.options.PipelineOptions;
import org.apache.beam.sdk.options.StreamingOptions;
import org.apache.beam.sdk.options.Validation;
import org.apache.beam.sdk.options.ValueProvider;

public interface SnowflakePipelineOptions extends PipelineOptions, StreamingOptions {
  String BASIC_CONNECTION_INFO_VALIDATION_GROUP = "BASIC_CONNECTION_INFO_GROUP";
  String AUTH_VALIDATION_GROUP = "AUTH_VALIDATION_GROUP";

  @Description(
      "Snowflake's JDBC-like url including account name and region without any parameters.")
  @Validation.Required(groups = BASIC_CONNECTION_INFO_VALIDATION_GROUP)
  String getUrl();

  void setUrl(String url);

  @Description("Server Name - full server name with account, zone and domain.")
  @Validation.Required(groups = BASIC_CONNECTION_INFO_VALIDATION_GROUP)
  ValueProvider getServerName();

  void setServerName(ValueProvider serverName);

  @Description("Username. Required for username/password and Private Key authentication.")
  @Validation.Required(groups = AUTH_VALIDATION_GROUP)
  ValueProvider getUsername();

  void setUsername(ValueProvider username);

  @Description("OAuth token. Required for OAuth authentication only.")
  @Validation.Required(groups = AUTH_VALIDATION_GROUP)
  String getOauthToken();

  void setOauthToken(String oauthToken);

  @Description("Password. Required for username/password authentication only.")
  @Default.String("")
  ValueProvider getPassword();

  void setPassword(ValueProvider password);

  @Description("Path to Private Key file. Required for Private Key authentication only.")
  @Default.String("")
  String getPrivateKeyPath();

  void setPrivateKeyPath(String privateKeyPath);

  @Description("Private key. Required for Private Key authentication only.")
  @Default.String("")
  ValueProvider getRawPrivateKey();

  void setRawPrivateKey(ValueProvider rawPrivateKey);

  @Description("Private Key's passphrase. Required for Private Key authentication only.")
  @Default.String("")
  ValueProvider getPrivateKeyPassphrase();

  void setPrivateKeyPassphrase(ValueProvider keyPassphrase);

  @Description("Warehouse to use. Optional.")
  @Default.String("")
  ValueProvider getWarehouse();

  void setWarehouse(ValueProvider warehouse);

  @Description("Database name to connect to. Optional.")
  @Default.String("")
  @Validation.Required
  ValueProvider getDatabase();

  void setDatabase(ValueProvider database);

  @Description("Schema to use. Optional.")
  @Default.String("")
  ValueProvider getSchema();

  void setSchema(ValueProvider schema);

  @Description("Table to use. Optional.")
  @Default.String("")
  ValueProvider getTable();

  void setTable(ValueProvider table);

  @Description("Query to use. Optional.")
  @Default.String("")
  ValueProvider getQuery();

  void setQuery(ValueProvider query);

  @Description("Role to use. Optional.")
  @Default.String("")
  ValueProvider getRole();

  void setRole(ValueProvider role);

  @Description("Authenticator to use. Optional.")
  @Default.String("")
  String getAuthenticator();

  void setAuthenticator(String authenticator);

  @Description("Port number. Optional.")
  @Default.String("")
  String getPortNumber();

  void setPortNumber(String portNumber);

  @Description("Login timeout. Optional.")
  @Default.String("")
  String getLoginTimeout();

  void setLoginTimeout(String loginTimeout);

  @Description("Temporary GCS bucket name.")
  @Validation.Required
  ValueProvider getStagingBucketName();

  void setStagingBucketName(ValueProvider stagingBucketName);

  @Description("Storage integration name")
  @Validation.Required
  ValueProvider getStorageIntegrationName();

  void setStorageIntegrationName(ValueProvider storageIntegrationName);

  @Description("SnowPipe name. Optional.")
  ValueProvider getSnowPipe();

  void setSnowPipe(ValueProvider snowPipe);
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy