object IngestionFailureEvent extends GeneratedMessageCompanion[IngestionFailureEvent]
- Alphabetic
- By Inheritance
- IngestionFailureEvent
- GeneratedMessageCompanion
- Serializable
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Type Members
- 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()
- 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()
- 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()
- 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()
- 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()
- 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()
- sealed trait Failure extends GeneratedOneof
- implicit class IngestionFailureEventLens[UpperPB] extends ObjectLens[UpperPB, IngestionFailureEvent]
- type ValueType = IngestionFailureEvent
- Definition Classes
- GeneratedMessageCompanion
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final val AWS_MSK_FAILURE_FIELD_NUMBER: Int(4)
- final val AZURE_EVENT_HUBS_FAILURE_FIELD_NUMBER: Int(5)
- final val CLOUD_STORAGE_FAILURE_FIELD_NUMBER: Int(3)
- final val CONFLUENT_CLOUD_FAILURE_FIELD_NUMBER: Int(6)
- final val ERROR_MESSAGE_FIELD_NUMBER: Int(2)
- final val TOPIC_FIELD_NUMBER: Int(1)
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @native()
- lazy val defaultInstance: IngestionFailureEvent
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- def enumCompanionForField(field: FieldDescriptor): GeneratedEnumCompanion[_]
- Definition Classes
- GeneratedMessageCompanion
- def enumCompanionForFieldNumber(__fieldNumber: Int): GeneratedEnumCompanion[_]
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable])
- def fromAscii(s: String): IngestionFailureEvent
- Definition Classes
- GeneratedMessageCompanion
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- def javaDescriptor: Descriptor
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- def merge(a: IngestionFailureEvent, input: CodedInputStream): IngestionFailureEvent
- Definition Classes
- GeneratedMessageCompanion
- implicit def messageCompanion: GeneratedMessageCompanion[IngestionFailureEvent]
- def messageCompanionForField(field: FieldDescriptor): GeneratedMessageCompanion[_]
- Definition Classes
- GeneratedMessageCompanion
- def messageCompanionForFieldNumber(__number: Int): GeneratedMessageCompanion[_]
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- implicit def messageReads: Reads[IngestionFailureEvent]
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- lazy val nestedMessagesCompanions: Seq[GeneratedMessageCompanion[_ <: GeneratedMessage]]
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- def of(topic: String, errorMessage: String, failure: Failure): IngestionFailureEvent
- def parseDelimitedFrom(input: InputStream): Option[IngestionFailureEvent]
- Definition Classes
- GeneratedMessageCompanion
- def parseDelimitedFrom(input: CodedInputStream): Option[IngestionFailureEvent]
- Definition Classes
- GeneratedMessageCompanion
- def parseFrom(_input__: CodedInputStream): IngestionFailureEvent
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- def parseFrom(s: Array[Byte]): IngestionFailureEvent
- Definition Classes
- GeneratedMessageCompanion
- def parseFrom(input: InputStream): IngestionFailureEvent
- Definition Classes
- GeneratedMessageCompanion
- def scalaDescriptor: Descriptor
- Definition Classes
- IngestionFailureEvent → GeneratedMessageCompanion
- def streamFromDelimitedInput(input: InputStream): Stream[IngestionFailureEvent]
- Definition Classes
- GeneratedMessageCompanion
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def toByteArray(a: IngestionFailureEvent): Array[Byte]
- Definition Classes
- GeneratedMessageCompanion
- def toString(): String
- Definition Classes
- AnyRef → Any
- def validate(s: Array[Byte]): Try[IngestionFailureEvent]
- Definition Classes
- GeneratedMessageCompanion
- def validateAscii(s: String): Either[TextFormatError, IngestionFailureEvent]
- Definition Classes
- GeneratedMessageCompanion
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- object ApiViolationReason extends GeneratedMessageCompanion[ApiViolationReason]
- object AvroFailureReason extends GeneratedMessageCompanion[AvroFailureReason]
- object AwsMskFailureReason extends GeneratedMessageCompanion[AwsMskFailureReason]
- object AzureEventHubsFailureReason extends GeneratedMessageCompanion[AzureEventHubsFailureReason]
- object CloudStorageFailure extends GeneratedMessageCompanion[CloudStorageFailure]
- object ConfluentCloudFailureReason extends GeneratedMessageCompanion[ConfluentCloudFailureReason]
- object Failure extends Serializable