object IngestionDataSourceSettings extends GeneratedMessageCompanion[IngestionDataSourceSettings]

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. IngestionDataSourceSettings
  2. GeneratedMessageCompanion
  3. Serializable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Type Members

  1. final case class AwsKinesis(state: State = com.google.pubsub.v1.pubsub.IngestionDataSourceSettings.AwsKinesis.State.STATE_UNSPECIFIED, streamArn: String = "", consumerArn: String = "", awsRoleArn: String = "", gcpServiceAccount: String = "", unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[AwsKinesis] with Product with Serializable

    Ingestion settings for Amazon Kinesis Data Streams.

    Ingestion settings for Amazon Kinesis Data Streams.

    state

    Output only. An output-only field that indicates the state of the Kinesis ingestion source.

    streamArn

    Required. The Kinesis stream ARN to ingest data from.

    consumerArn

    Required. The Kinesis consumer ARN to used for ingestion in Enhanced Fan-Out mode. The consumer must be already created and ready to be used.

    awsRoleArn

    Required. AWS role ARN to be used for Federated Identity authentication with Kinesis. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.

    gcpServiceAccount

    Required. The GCP service account to be used for Federated Identity authentication with Kinesis (via a AssumeRoleWithWebIdentity call for the provided role). The aws_role_arn must be set up with accounts.google.com:sub equals to this service account number.

    Annotations
    @SerialVersionUID()
  2. final case class AwsMsk(state: State = com.google.pubsub.v1.pubsub.IngestionDataSourceSettings.AwsMsk.State.STATE_UNSPECIFIED, clusterArn: String = "", topic: String = "", awsRoleArn: String = "", gcpServiceAccount: String = "", unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[AwsMsk] with Product with Serializable

    Ingestion settings for Amazon MSK.

    Ingestion settings for Amazon MSK.

    state

    Output only. An output-only field that indicates the state of the Amazon MSK ingestion source.

    clusterArn

    Required. The Amazon Resource Name (ARN) that uniquely identifies the cluster.

    topic

    Required. The name of the topic in the Amazon MSK cluster that Pub/Sub will import from.

    awsRoleArn

    Required. AWS role ARN to be used for Federated Identity authentication with Amazon MSK. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.

    gcpServiceAccount

    Required. The GCP service account to be used for Federated Identity authentication with Amazon MSK (via a AssumeRoleWithWebIdentity call for the provided role). The aws_role_arn must be set up with accounts.google.com:sub equals to this service account number.

    Annotations
    @SerialVersionUID()
  3. final case class AzureEventHubs(state: State = com.google.pubsub.v1.pubsub.IngestionDataSourceSettings.AzureEventHubs.State.STATE_UNSPECIFIED, resourceGroup: String = "", namespace: String = "", eventHub: String = "", clientId: String = "", tenantId: String = "", subscriptionId: String = "", gcpServiceAccount: String = "", unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[AzureEventHubs] with Product with Serializable

    Ingestion settings for Azure Event Hubs.

    Ingestion settings for Azure Event Hubs.

    state

    Output only. An output-only field that indicates the state of the Event Hubs ingestion source.

    resourceGroup

    Optional. Name of the resource group within the azure subscription.

    namespace

    Optional. The name of the Event Hubs namespace.

    eventHub

    Optional. The name of the Event Hub.

    clientId

    Optional. The client id of the Azure application that is being used to authenticate Pub/Sub.

    tenantId

    Optional. The tenant id of the Azure application that is being used to authenticate Pub/Sub.

    subscriptionId

    Optional. The Azure subscription id.

    gcpServiceAccount

    Optional. The GCP service account to be used for Federated Identity authentication.

    Annotations
    @SerialVersionUID()
  4. final case class CloudStorage(state: State = com.google.pubsub.v1.pubsub.IngestionDataSourceSettings.CloudStorage.State.STATE_UNSPECIFIED, bucket: String = "", inputFormat: InputFormat = com.google.pubsub.v1.pubsub.IngestionDataSourceSettings.CloudStorage.InputFormat.Empty, minimumObjectCreateTime: Option[Timestamp] = _root_.scala.None, matchGlob: String = "", unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[CloudStorage] with Product with Serializable

    Ingestion settings for Cloud Storage.

    Ingestion settings for Cloud Storage.

    state

    Output only. An output-only field that indicates the state of the Cloud Storage ingestion source.

    bucket

    Optional. Cloud Storage bucket. The bucket name must be without any prefix like "gs://". See the [bucket naming requirements] (https://cloud.google.com/storage/docs/buckets#naming).

    minimumObjectCreateTime

    Optional. Only objects with a larger or equal creation timestamp will be ingested.

    matchGlob

    Optional. Glob pattern used to match objects that will be ingested. If unset, all objects will be ingested. See the [supported patterns](https://cloud.google.com/storage/docs/json_api/v1/objects/list#list-objects-and-prefixes-using-glob).

    Annotations
    @SerialVersionUID()
  5. final case class ConfluentCloud(state: State = com.google.pubsub.v1.pubsub.IngestionDataSourceSettings.ConfluentCloud.State.STATE_UNSPECIFIED, bootstrapServer: String = "", clusterId: String = "", topic: String = "", identityPoolId: String = "", gcpServiceAccount: String = "", unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConfluentCloud] with Product with Serializable

    Ingestion settings for Confluent Cloud.

    Ingestion settings for Confluent Cloud.

    state

    Output only. An output-only field that indicates the state of the Confluent Cloud ingestion source.

    bootstrapServer

    Required. The address of the bootstrap server. The format is url:port.

    clusterId

    Required. The id of the cluster.

    topic

    Required. The name of the topic in the Confluent Cloud cluster that Pub/Sub will import from.

    identityPoolId

    Required. The id of the identity pool to be used for Federated Identity authentication with Confluent Cloud. See https://docs.confluent.io/cloud/current/security/authenticate/workload-identities/identity-providers/oauth/identity-pools.html#add-oauth-identity-pools.

    gcpServiceAccount

    Required. The GCP service account to be used for Federated Identity authentication with identity_pool_id.

    Annotations
    @SerialVersionUID()
  6. implicit class IngestionDataSourceSettingsLens[UpperPB] extends ObjectLens[UpperPB, IngestionDataSourceSettings]
  7. sealed trait Source extends GeneratedOneof
  8. type ValueType = IngestionDataSourceSettings
    Definition Classes
    GeneratedMessageCompanion

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final val AWS_KINESIS_FIELD_NUMBER: Int(1)
  5. final val AWS_MSK_FIELD_NUMBER: Int(5)
  6. final val AZURE_EVENT_HUBS_FIELD_NUMBER: Int(3)
  7. final val CLOUD_STORAGE_FIELD_NUMBER: Int(2)
  8. final val CONFLUENT_CLOUD_FIELD_NUMBER: Int(6)
  9. final val PLATFORM_LOGS_SETTINGS_FIELD_NUMBER: Int(4)
  10. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  11. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native()
  12. lazy val defaultInstance: IngestionDataSourceSettings
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  13. def enumCompanionForField(field: FieldDescriptor): GeneratedEnumCompanion[_]
    Definition Classes
    GeneratedMessageCompanion
  14. def enumCompanionForFieldNumber(__fieldNumber: Int): GeneratedEnumCompanion[_]
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  15. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  16. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  17. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable])
  18. def fromAscii(s: String): IngestionDataSourceSettings
    Definition Classes
    GeneratedMessageCompanion
  19. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  20. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  21. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  22. def javaDescriptor: Descriptor
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  23. def merge(a: IngestionDataSourceSettings, input: CodedInputStream): IngestionDataSourceSettings
    Definition Classes
    GeneratedMessageCompanion
  24. implicit def messageCompanion: GeneratedMessageCompanion[IngestionDataSourceSettings]
  25. def messageCompanionForField(field: FieldDescriptor): GeneratedMessageCompanion[_]
    Definition Classes
    GeneratedMessageCompanion
  26. def messageCompanionForFieldNumber(__number: Int): GeneratedMessageCompanion[_]
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  27. implicit def messageReads: Reads[IngestionDataSourceSettings]
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  28. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  29. lazy val nestedMessagesCompanions: Seq[GeneratedMessageCompanion[_ <: GeneratedMessage]]
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  30. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  31. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  32. def of(source: Source, platformLogsSettings: Option[PlatformLogsSettings]): IngestionDataSourceSettings
  33. def parseDelimitedFrom(input: InputStream): Option[IngestionDataSourceSettings]
    Definition Classes
    GeneratedMessageCompanion
  34. def parseDelimitedFrom(input: CodedInputStream): Option[IngestionDataSourceSettings]
    Definition Classes
    GeneratedMessageCompanion
  35. def parseFrom(_input__: CodedInputStream): IngestionDataSourceSettings
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  36. def parseFrom(s: Array[Byte]): IngestionDataSourceSettings
    Definition Classes
    GeneratedMessageCompanion
  37. def parseFrom(input: InputStream): IngestionDataSourceSettings
    Definition Classes
    GeneratedMessageCompanion
  38. def scalaDescriptor: Descriptor
    Definition Classes
    IngestionDataSourceSettings → GeneratedMessageCompanion
  39. def streamFromDelimitedInput(input: InputStream): Stream[IngestionDataSourceSettings]
    Definition Classes
    GeneratedMessageCompanion
  40. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  41. def toByteArray(a: IngestionDataSourceSettings): Array[Byte]
    Definition Classes
    GeneratedMessageCompanion
  42. def toString(): String
    Definition Classes
    AnyRef → Any
  43. def validate(s: Array[Byte]): Try[IngestionDataSourceSettings]
    Definition Classes
    GeneratedMessageCompanion
  44. def validateAscii(s: String): Either[TextFormatError, IngestionDataSourceSettings]
    Definition Classes
    GeneratedMessageCompanion
  45. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  46. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  47. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  48. object AwsKinesis extends GeneratedMessageCompanion[AwsKinesis]
  49. object AwsMsk extends GeneratedMessageCompanion[AwsMsk]
  50. object AzureEventHubs extends GeneratedMessageCompanion[AzureEventHubs]
  51. object CloudStorage extends GeneratedMessageCompanion[CloudStorage]
  52. object ConfluentCloud extends GeneratedMessageCompanion[ConfluentCloud]
  53. object Source extends Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped