Interface StoreTypes.TaskMetricsOrBuilder

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

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

    • getExecutorDeserializeTime

      long getExecutorDeserializeTime()
      int64 executor_deserialize_time = 1;
      Returns:
      The executorDeserializeTime.
    • getExecutorDeserializeCpuTime

      long getExecutorDeserializeCpuTime()
      int64 executor_deserialize_cpu_time = 2;
      Returns:
      The executorDeserializeCpuTime.
    • getExecutorRunTime

      long getExecutorRunTime()
      int64 executor_run_time = 3;
      Returns:
      The executorRunTime.
    • getExecutorCpuTime

      long getExecutorCpuTime()
      int64 executor_cpu_time = 4;
      Returns:
      The executorCpuTime.
    • getResultSize

      long getResultSize()
      int64 result_size = 5;
      Returns:
      The resultSize.
    • getJvmGcTime

      long getJvmGcTime()
      int64 jvm_gc_time = 6;
      Returns:
      The jvmGcTime.
    • getResultSerializationTime

      long getResultSerializationTime()
      int64 result_serialization_time = 7;
      Returns:
      The resultSerializationTime.
    • getMemoryBytesSpilled

      long getMemoryBytesSpilled()
      int64 memory_bytes_spilled = 8;
      Returns:
      The memoryBytesSpilled.
    • getDiskBytesSpilled

      long getDiskBytesSpilled()
      int64 disk_bytes_spilled = 9;
      Returns:
      The diskBytesSpilled.
    • getPeakExecutionMemory

      long getPeakExecutionMemory()
      int64 peak_execution_memory = 10;
      Returns:
      The peakExecutionMemory.
    • hasInputMetrics

      boolean hasInputMetrics()
      .org.apache.spark.status.protobuf.InputMetrics input_metrics = 11;
      Returns:
      Whether the inputMetrics field is set.
    • getInputMetrics

      StoreTypes.InputMetrics getInputMetrics()
      .org.apache.spark.status.protobuf.InputMetrics input_metrics = 11;
      Returns:
      The inputMetrics.
    • getInputMetricsOrBuilder

      StoreTypes.InputMetricsOrBuilder getInputMetricsOrBuilder()
      .org.apache.spark.status.protobuf.InputMetrics input_metrics = 11;
    • hasOutputMetrics

      boolean hasOutputMetrics()
      .org.apache.spark.status.protobuf.OutputMetrics output_metrics = 12;
      Returns:
      Whether the outputMetrics field is set.
    • getOutputMetrics

      StoreTypes.OutputMetrics getOutputMetrics()
      .org.apache.spark.status.protobuf.OutputMetrics output_metrics = 12;
      Returns:
      The outputMetrics.
    • getOutputMetricsOrBuilder

      StoreTypes.OutputMetricsOrBuilder getOutputMetricsOrBuilder()
      .org.apache.spark.status.protobuf.OutputMetrics output_metrics = 12;
    • hasShuffleReadMetrics

      boolean hasShuffleReadMetrics()
      .org.apache.spark.status.protobuf.ShuffleReadMetrics shuffle_read_metrics = 13;
      Returns:
      Whether the shuffleReadMetrics field is set.
    • getShuffleReadMetrics

      StoreTypes.ShuffleReadMetrics getShuffleReadMetrics()
      .org.apache.spark.status.protobuf.ShuffleReadMetrics shuffle_read_metrics = 13;
      Returns:
      The shuffleReadMetrics.
    • getShuffleReadMetricsOrBuilder

      StoreTypes.ShuffleReadMetricsOrBuilder getShuffleReadMetricsOrBuilder()
      .org.apache.spark.status.protobuf.ShuffleReadMetrics shuffle_read_metrics = 13;
    • hasShuffleWriteMetrics

      boolean hasShuffleWriteMetrics()
      .org.apache.spark.status.protobuf.ShuffleWriteMetrics shuffle_write_metrics = 14;
      Returns:
      Whether the shuffleWriteMetrics field is set.
    • getShuffleWriteMetrics

      StoreTypes.ShuffleWriteMetrics getShuffleWriteMetrics()
      .org.apache.spark.status.protobuf.ShuffleWriteMetrics shuffle_write_metrics = 14;
      Returns:
      The shuffleWriteMetrics.
    • getShuffleWriteMetricsOrBuilder

      StoreTypes.ShuffleWriteMetricsOrBuilder getShuffleWriteMetricsOrBuilder()
      .org.apache.spark.status.protobuf.ShuffleWriteMetrics shuffle_write_metrics = 14;