Interface StoreTypes.StreamingQueryProgressOrBuilder

All Superinterfaces:
com.google.protobuf.MessageLiteOrBuilder, com.google.protobuf.MessageOrBuilder
All Known Implementing Classes:
StoreTypes.StreamingQueryProgress, StoreTypes.StreamingQueryProgress.Builder
Enclosing class:
StoreTypes

public static interface StoreTypes.StreamingQueryProgressOrBuilder extends com.google.protobuf.MessageOrBuilder
  • Method Details

    • hasId

      boolean hasId()
      optional string id = 1;
      Returns:
      Whether the id field is set.
    • getId

      String getId()
      optional string id = 1;
      Returns:
      The id.
    • getIdBytes

      com.google.protobuf.ByteString getIdBytes()
      optional string id = 1;
      Returns:
      The bytes for id.
    • hasRunId

      boolean hasRunId()
      optional string run_id = 2;
      Returns:
      Whether the runId field is set.
    • getRunId

      String getRunId()
      optional string run_id = 2;
      Returns:
      The runId.
    • getRunIdBytes

      com.google.protobuf.ByteString getRunIdBytes()
      optional string run_id = 2;
      Returns:
      The bytes for runId.
    • hasName

      boolean hasName()
      optional string name = 3;
      Returns:
      Whether the name field is set.
    • getName

      String getName()
      optional string name = 3;
      Returns:
      The name.
    • getNameBytes

      com.google.protobuf.ByteString getNameBytes()
      optional string name = 3;
      Returns:
      The bytes for name.
    • hasTimestamp

      boolean hasTimestamp()
      optional string timestamp = 4;
      Returns:
      Whether the timestamp field is set.
    • getTimestamp

      String getTimestamp()
      optional string timestamp = 4;
      Returns:
      The timestamp.
    • getTimestampBytes

      com.google.protobuf.ByteString getTimestampBytes()
      optional string timestamp = 4;
      Returns:
      The bytes for timestamp.
    • getBatchId

      long getBatchId()
      int64 batch_id = 5;
      Returns:
      The batchId.
    • getBatchDuration

      long getBatchDuration()
      int64 batch_duration = 6;
      Returns:
      The batchDuration.
    • getDurationMsCount

      int getDurationMsCount()
      map<string, int64> duration_ms = 7;
    • containsDurationMs

      boolean containsDurationMs(String key)
      map<string, int64> duration_ms = 7;
    • getDurationMs

      @Deprecated Map<String,Long> getDurationMs()
      Deprecated.
      Use getDurationMsMap() instead.
    • getDurationMsMap

      Map<String,Long> getDurationMsMap()
      map<string, int64> duration_ms = 7;
    • getDurationMsOrDefault

      long getDurationMsOrDefault(String key, long defaultValue)
      map<string, int64> duration_ms = 7;
    • getDurationMsOrThrow

      long getDurationMsOrThrow(String key)
      map<string, int64> duration_ms = 7;
    • getEventTimeCount

      int getEventTimeCount()
      map<string, string> event_time = 8;
    • containsEventTime

      boolean containsEventTime(String key)
      map<string, string> event_time = 8;
    • getEventTime

      @Deprecated Map<String,String> getEventTime()
      Deprecated.
      Use getEventTimeMap() instead.
    • getEventTimeMap

      Map<String,String> getEventTimeMap()
      map<string, string> event_time = 8;
    • getEventTimeOrDefault

      String getEventTimeOrDefault(String key, String defaultValue)
      map<string, string> event_time = 8;
    • getEventTimeOrThrow

      String getEventTimeOrThrow(String key)
      map<string, string> event_time = 8;
    • getStateOperatorsList

      List<StoreTypes.StateOperatorProgress> getStateOperatorsList()
      repeated .org.apache.spark.status.protobuf.StateOperatorProgress state_operators = 9;
    • getStateOperators

      StoreTypes.StateOperatorProgress getStateOperators(int index)
      repeated .org.apache.spark.status.protobuf.StateOperatorProgress state_operators = 9;
    • getStateOperatorsCount

      int getStateOperatorsCount()
      repeated .org.apache.spark.status.protobuf.StateOperatorProgress state_operators = 9;
    • getStateOperatorsOrBuilderList

      List<? extends StoreTypes.StateOperatorProgressOrBuilder> getStateOperatorsOrBuilderList()
      repeated .org.apache.spark.status.protobuf.StateOperatorProgress state_operators = 9;
    • getStateOperatorsOrBuilder

      StoreTypes.StateOperatorProgressOrBuilder getStateOperatorsOrBuilder(int index)
      repeated .org.apache.spark.status.protobuf.StateOperatorProgress state_operators = 9;
    • getSourcesList

      List<StoreTypes.SourceProgress> getSourcesList()
      repeated .org.apache.spark.status.protobuf.SourceProgress sources = 10;
    • getSources

      StoreTypes.SourceProgress getSources(int index)
      repeated .org.apache.spark.status.protobuf.SourceProgress sources = 10;
    • getSourcesCount

      int getSourcesCount()
      repeated .org.apache.spark.status.protobuf.SourceProgress sources = 10;
    • getSourcesOrBuilderList

      List<? extends StoreTypes.SourceProgressOrBuilder> getSourcesOrBuilderList()
      repeated .org.apache.spark.status.protobuf.SourceProgress sources = 10;
    • getSourcesOrBuilder

      StoreTypes.SourceProgressOrBuilder getSourcesOrBuilder(int index)
      repeated .org.apache.spark.status.protobuf.SourceProgress sources = 10;
    • hasSink

      boolean hasSink()
      .org.apache.spark.status.protobuf.SinkProgress sink = 11;
      Returns:
      Whether the sink field is set.
    • getSink

      .org.apache.spark.status.protobuf.SinkProgress sink = 11;
      Returns:
      The sink.
    • getSinkOrBuilder

      .org.apache.spark.status.protobuf.SinkProgress sink = 11;
    • getObservedMetricsCount

      int getObservedMetricsCount()
      map<string, string> observed_metrics = 12;
    • containsObservedMetrics

      boolean containsObservedMetrics(String key)
      map<string, string> observed_metrics = 12;
    • getObservedMetrics

      @Deprecated Map<String,String> getObservedMetrics()
      Deprecated.
    • getObservedMetricsMap

      Map<String,String> getObservedMetricsMap()
      map<string, string> observed_metrics = 12;
    • getObservedMetricsOrDefault

      String getObservedMetricsOrDefault(String key, String defaultValue)
      map<string, string> observed_metrics = 12;
    • getObservedMetricsOrThrow

      String getObservedMetricsOrThrow(String key)
      map<string, string> observed_metrics = 12;