object IngestionFailureEvent extends GeneratedMessageCompanion[IngestionFailureEvent]

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. IngestionFailureEvent
  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 ApiViolationReason(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ApiViolationReason] with Product with Serializable

    Specifies the reason why some data may have been left out of the desired Pub/Sub message due to the API message limits (https://cloud.google.com/pubsub/quotas#resource_limits).

    Specifies the reason why some data may have been left out of the desired Pub/Sub message due to the API message limits (https://cloud.google.com/pubsub/quotas#resource_limits). For example, when the number of attributes is larger than 100, the number of attributes is truncated to 100 to respect the limit on the attribute count. Other attribute limits are treated similarly. When the size of the desired message would've been larger than 10MB, the message won't be published at all, and ingestion of the subsequent messages will proceed as normal.

    Annotations
    @SerialVersionUID()
  2. final case class AvroFailureReason(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[AvroFailureReason] with Product with Serializable

    Set when an Avro file is unsupported or its format is not valid.

    Set when an Avro file is unsupported or its format is not valid. When this occurs, one or more Avro objects won't be ingested.

    Annotations
    @SerialVersionUID()
  3. final case class AwsMskFailureReason(clusterArn: String = "", kafkaTopic: String = "", partitionId: Long = 0L, offset: Long = 0L, reason: Reason = com.google.pubsub.v1.pubsub.IngestionFailureEvent.AwsMskFailureReason.Reason.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[AwsMskFailureReason] with Product with Serializable

    Failure when ingesting from an Amazon MSK source.

    Failure when ingesting from an Amazon MSK source.

    clusterArn

    Optional. The ARN of the cluster of the topic being ingested from.

    kafkaTopic

    Optional. The name of the Kafka topic being ingested from.

    partitionId

    Optional. The partition ID of the message that failed to be ingested.

    offset

    Optional. The offset within the partition of the message that failed to be ingested.

    Annotations
    @SerialVersionUID()
  4. final case class AzureEventHubsFailureReason(namespace: String = "", eventHub: String = "", partitionId: Long = 0L, offset: Long = 0L, reason: Reason = com.google.pubsub.v1.pubsub.IngestionFailureEvent.AzureEventHubsFailureReason.Reason.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[AzureEventHubsFailureReason] with Product with Serializable

    Failure when ingesting from an Azure Event Hubs source.

    Failure when ingesting from an Azure Event Hubs source.

    namespace

    Optional. The namespace containing the event hub being ingested from.

    eventHub

    Optional. The name of the event hub being ingested from.

    partitionId

    Optional. The partition ID of the message that failed to be ingested.

    offset

    Optional. The offset within the partition of the message that failed to be ingested.

    Annotations
    @SerialVersionUID()
  5. final case class CloudStorageFailure(bucket: String = "", objectName: String = "", objectGeneration: Long = 0L, reason: Reason = com.google.pubsub.v1.pubsub.IngestionFailureEvent.CloudStorageFailure.Reason.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[CloudStorageFailure] with Product with Serializable

    Failure when ingesting from a Cloud Storage source.

    Failure when ingesting from a Cloud Storage source.

    bucket

    Optional. Name of the Cloud Storage bucket used for ingestion.

    objectName

    Optional. Name of the Cloud Storage object which contained the section that couldn't be ingested.

    objectGeneration

    Optional. Generation of the Cloud Storage object which contained the section that couldn't be ingested.

    Annotations
    @SerialVersionUID()
  6. final case class ConfluentCloudFailureReason(clusterId: String = "", kafkaTopic: String = "", partitionId: Long = 0L, offset: Long = 0L, reason: Reason = com.google.pubsub.v1.pubsub.IngestionFailureEvent.ConfluentCloudFailureReason.Reason.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConfluentCloudFailureReason] with Product with Serializable

    Failure when ingesting from a Confluent Cloud source.

    Failure when ingesting from a Confluent Cloud source.

    clusterId

    Optional. The cluster ID containing the topic being ingested from.

    kafkaTopic

    Optional. The name of the Kafka topic being ingested from.

    partitionId

    Optional. The partition ID of the message that failed to be ingested.

    offset

    Optional. The offset within the partition of the message that failed to be ingested.

    Annotations
    @SerialVersionUID()
  7. sealed trait Failure extends GeneratedOneof
  8. implicit class IngestionFailureEventLens[UpperPB] extends ObjectLens[UpperPB, IngestionFailureEvent]
  9. type ValueType = IngestionFailureEvent
    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_MSK_FAILURE_FIELD_NUMBER: Int(4)
  5. final val AZURE_EVENT_HUBS_FAILURE_FIELD_NUMBER: Int(5)
  6. final val CLOUD_STORAGE_FAILURE_FIELD_NUMBER: Int(3)
  7. final val CONFLUENT_CLOUD_FAILURE_FIELD_NUMBER: Int(6)
  8. final val ERROR_MESSAGE_FIELD_NUMBER: Int(2)
  9. final val TOPIC_FIELD_NUMBER: Int(1)
  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: IngestionFailureEvent
    Definition Classes
    IngestionFailureEvent → GeneratedMessageCompanion
  13. def enumCompanionForField(field: FieldDescriptor): GeneratedEnumCompanion[_]
    Definition Classes
    GeneratedMessageCompanion
  14. def enumCompanionForFieldNumber(__fieldNumber: Int): GeneratedEnumCompanion[_]
    Definition Classes
    IngestionFailureEvent → 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): IngestionFailureEvent
    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
    IngestionFailureEvent → GeneratedMessageCompanion
  23. def merge(a: IngestionFailureEvent, input: CodedInputStream): IngestionFailureEvent
    Definition Classes
    GeneratedMessageCompanion
  24. implicit def messageCompanion: GeneratedMessageCompanion[IngestionFailureEvent]
  25. def messageCompanionForField(field: FieldDescriptor): GeneratedMessageCompanion[_]
    Definition Classes
    GeneratedMessageCompanion
  26. def messageCompanionForFieldNumber(__number: Int): GeneratedMessageCompanion[_]
    Definition Classes
    IngestionFailureEvent → GeneratedMessageCompanion
  27. implicit def messageReads: Reads[IngestionFailureEvent]
    Definition Classes
    IngestionFailureEvent → GeneratedMessageCompanion
  28. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  29. lazy val nestedMessagesCompanions: Seq[GeneratedMessageCompanion[_ <: GeneratedMessage]]
    Definition Classes
    IngestionFailureEvent → GeneratedMessageCompanion
  30. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  31. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  32. def of(topic: String, errorMessage: String, failure: Failure): IngestionFailureEvent
  33. def parseDelimitedFrom(input: InputStream): Option[IngestionFailureEvent]
    Definition Classes
    GeneratedMessageCompanion
  34. def parseDelimitedFrom(input: CodedInputStream): Option[IngestionFailureEvent]
    Definition Classes
    GeneratedMessageCompanion
  35. def parseFrom(_input__: CodedInputStream): IngestionFailureEvent
    Definition Classes
    IngestionFailureEvent → GeneratedMessageCompanion
  36. def parseFrom(s: Array[Byte]): IngestionFailureEvent
    Definition Classes
    GeneratedMessageCompanion
  37. def parseFrom(input: InputStream): IngestionFailureEvent
    Definition Classes
    GeneratedMessageCompanion
  38. def scalaDescriptor: Descriptor
    Definition Classes
    IngestionFailureEvent → GeneratedMessageCompanion
  39. def streamFromDelimitedInput(input: InputStream): Stream[IngestionFailureEvent]
    Definition Classes
    GeneratedMessageCompanion
  40. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  41. def toByteArray(a: IngestionFailureEvent): Array[Byte]
    Definition Classes
    GeneratedMessageCompanion
  42. def toString(): String
    Definition Classes
    AnyRef → Any
  43. def validate(s: Array[Byte]): Try[IngestionFailureEvent]
    Definition Classes
    GeneratedMessageCompanion
  44. def validateAscii(s: String): Either[TextFormatError, IngestionFailureEvent]
    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 ApiViolationReason extends GeneratedMessageCompanion[ApiViolationReason]
  49. object AvroFailureReason extends GeneratedMessageCompanion[AvroFailureReason]
  50. object AwsMskFailureReason extends GeneratedMessageCompanion[AwsMskFailureReason]
  51. object AzureEventHubsFailureReason extends GeneratedMessageCompanion[AzureEventHubsFailureReason]
  52. object CloudStorageFailure extends GeneratedMessageCompanion[CloudStorageFailure]
  53. object ConfluentCloudFailureReason extends GeneratedMessageCompanion[ConfluentCloudFailureReason]
  54. object Failure extends Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped