public static interface IngestionFailureEvent.ConfluentCloudFailureReasonOrBuilder extends MessageOrBuilderImplements
MessageOrBuilderMethods
getApiViolationReason()
public abstract IngestionFailureEvent.ApiViolationReason getApiViolationReason()Optional. The Pub/Sub API limits prevented the desired message from being published.
 
 .google.pubsub.v1.IngestionFailureEvent.ApiViolationReason api_violation_reason = 5 [(.google.api.field_behavior) = OPTIONAL];
 
| Returns | |
|---|---|
| Type | Description | 
IngestionFailureEvent.ApiViolationReason | 
        The apiViolationReason.  | 
      
getApiViolationReasonOrBuilder()
public abstract IngestionFailureEvent.ApiViolationReasonOrBuilder getApiViolationReasonOrBuilder()Optional. The Pub/Sub API limits prevented the desired message from being published.
 
 .google.pubsub.v1.IngestionFailureEvent.ApiViolationReason api_violation_reason = 5 [(.google.api.field_behavior) = OPTIONAL];
 
| Returns | |
|---|---|
| Type | Description | 
IngestionFailureEvent.ApiViolationReasonOrBuilder | 
        |
getClusterId()
public abstract String getClusterId()Optional. The cluster ID containing the topic being ingested from.
 string cluster_id = 1 [(.google.api.field_behavior) = OPTIONAL];
| Returns | |
|---|---|
| Type | Description | 
String | 
        The clusterId.  | 
      
getClusterIdBytes()
public abstract ByteString getClusterIdBytes()Optional. The cluster ID containing the topic being ingested from.
 string cluster_id = 1 [(.google.api.field_behavior) = OPTIONAL];
| Returns | |
|---|---|
| Type | Description | 
ByteString | 
        The bytes for clusterId.  | 
      
getKafkaTopic()
public abstract String getKafkaTopic()Optional. The name of the Kafka topic being ingested from.
 string kafka_topic = 2 [(.google.api.field_behavior) = OPTIONAL];
| Returns | |
|---|---|
| Type | Description | 
String | 
        The kafkaTopic.  | 
      
getKafkaTopicBytes()
public abstract ByteString getKafkaTopicBytes()Optional. The name of the Kafka topic being ingested from.
 string kafka_topic = 2 [(.google.api.field_behavior) = OPTIONAL];
| Returns | |
|---|---|
| Type | Description | 
ByteString | 
        The bytes for kafkaTopic.  | 
      
getOffset()
public abstract long getOffset()Optional. The offset within the partition of the message that failed to be ingested.
 int64 offset = 4 [(.google.api.field_behavior) = OPTIONAL];
| Returns | |
|---|---|
| Type | Description | 
long | 
        The offset.  | 
      
getPartitionId()
public abstract long getPartitionId()Optional. The partition ID of the message that failed to be ingested.
 int64 partition_id = 3 [(.google.api.field_behavior) = OPTIONAL];
| Returns | |
|---|---|
| Type | Description | 
long | 
        The partitionId.  | 
      
getReasonCase()
public abstract IngestionFailureEvent.ConfluentCloudFailureReason.ReasonCase getReasonCase()| Returns | |
|---|---|
| Type | Description | 
IngestionFailureEvent.ConfluentCloudFailureReason.ReasonCase | 
        |
hasApiViolationReason()
public abstract boolean hasApiViolationReason()Optional. The Pub/Sub API limits prevented the desired message from being published.
 
 .google.pubsub.v1.IngestionFailureEvent.ApiViolationReason api_violation_reason = 5 [(.google.api.field_behavior) = OPTIONAL];
 
| Returns | |
|---|---|
| Type | Description | 
boolean | 
        Whether the apiViolationReason field is set.  |