Interface StoreTypes.ExecutorMetricsDistributionsOrBuilder

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

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

    • getQuantilesList

      List<Double> getQuantilesList()
      repeated double quantiles = 1;
      Returns:
      A list containing the quantiles.
    • getQuantilesCount

      int getQuantilesCount()
      repeated double quantiles = 1;
      Returns:
      The count of quantiles.
    • getQuantiles

      double getQuantiles(int index)
      repeated double quantiles = 1;
      Parameters:
      index - The index of the element to return.
      Returns:
      The quantiles at the given index.
    • getTaskTimeList

      List<Double> getTaskTimeList()
      repeated double task_time = 2;
      Returns:
      A list containing the taskTime.
    • getTaskTimeCount

      int getTaskTimeCount()
      repeated double task_time = 2;
      Returns:
      The count of taskTime.
    • getTaskTime

      double getTaskTime(int index)
      repeated double task_time = 2;
      Parameters:
      index - The index of the element to return.
      Returns:
      The taskTime at the given index.
    • getFailedTasksList

      List<Double> getFailedTasksList()
      repeated double failed_tasks = 3;
      Returns:
      A list containing the failedTasks.
    • getFailedTasksCount

      int getFailedTasksCount()
      repeated double failed_tasks = 3;
      Returns:
      The count of failedTasks.
    • getFailedTasks

      double getFailedTasks(int index)
      repeated double failed_tasks = 3;
      Parameters:
      index - The index of the element to return.
      Returns:
      The failedTasks at the given index.
    • getSucceededTasksList

      List<Double> getSucceededTasksList()
      repeated double succeeded_tasks = 4;
      Returns:
      A list containing the succeededTasks.
    • getSucceededTasksCount

      int getSucceededTasksCount()
      repeated double succeeded_tasks = 4;
      Returns:
      The count of succeededTasks.
    • getSucceededTasks

      double getSucceededTasks(int index)
      repeated double succeeded_tasks = 4;
      Parameters:
      index - The index of the element to return.
      Returns:
      The succeededTasks at the given index.
    • getKilledTasksList

      List<Double> getKilledTasksList()
      repeated double killed_tasks = 5;
      Returns:
      A list containing the killedTasks.
    • getKilledTasksCount

      int getKilledTasksCount()
      repeated double killed_tasks = 5;
      Returns:
      The count of killedTasks.
    • getKilledTasks

      double getKilledTasks(int index)
      repeated double killed_tasks = 5;
      Parameters:
      index - The index of the element to return.
      Returns:
      The killedTasks at the given index.
    • getInputBytesList

      List<Double> getInputBytesList()
      repeated double input_bytes = 6;
      Returns:
      A list containing the inputBytes.
    • getInputBytesCount

      int getInputBytesCount()
      repeated double input_bytes = 6;
      Returns:
      The count of inputBytes.
    • getInputBytes

      double getInputBytes(int index)
      repeated double input_bytes = 6;
      Parameters:
      index - The index of the element to return.
      Returns:
      The inputBytes at the given index.
    • getInputRecordsList

      List<Double> getInputRecordsList()
      repeated double input_records = 7;
      Returns:
      A list containing the inputRecords.
    • getInputRecordsCount

      int getInputRecordsCount()
      repeated double input_records = 7;
      Returns:
      The count of inputRecords.
    • getInputRecords

      double getInputRecords(int index)
      repeated double input_records = 7;
      Parameters:
      index - The index of the element to return.
      Returns:
      The inputRecords at the given index.
    • getOutputBytesList

      List<Double> getOutputBytesList()
      repeated double output_bytes = 8;
      Returns:
      A list containing the outputBytes.
    • getOutputBytesCount

      int getOutputBytesCount()
      repeated double output_bytes = 8;
      Returns:
      The count of outputBytes.
    • getOutputBytes

      double getOutputBytes(int index)
      repeated double output_bytes = 8;
      Parameters:
      index - The index of the element to return.
      Returns:
      The outputBytes at the given index.
    • getOutputRecordsList

      List<Double> getOutputRecordsList()
      repeated double output_records = 9;
      Returns:
      A list containing the outputRecords.
    • getOutputRecordsCount

      int getOutputRecordsCount()
      repeated double output_records = 9;
      Returns:
      The count of outputRecords.
    • getOutputRecords

      double getOutputRecords(int index)
      repeated double output_records = 9;
      Parameters:
      index - The index of the element to return.
      Returns:
      The outputRecords at the given index.
    • getShuffleReadList

      List<Double> getShuffleReadList()
      repeated double shuffle_read = 10;
      Returns:
      A list containing the shuffleRead.
    • getShuffleReadCount

      int getShuffleReadCount()
      repeated double shuffle_read = 10;
      Returns:
      The count of shuffleRead.
    • getShuffleRead

      double getShuffleRead(int index)
      repeated double shuffle_read = 10;
      Parameters:
      index - The index of the element to return.
      Returns:
      The shuffleRead at the given index.
    • getShuffleReadRecordsList

      List<Double> getShuffleReadRecordsList()
      repeated double shuffle_read_records = 11;
      Returns:
      A list containing the shuffleReadRecords.
    • getShuffleReadRecordsCount

      int getShuffleReadRecordsCount()
      repeated double shuffle_read_records = 11;
      Returns:
      The count of shuffleReadRecords.
    • getShuffleReadRecords

      double getShuffleReadRecords(int index)
      repeated double shuffle_read_records = 11;
      Parameters:
      index - The index of the element to return.
      Returns:
      The shuffleReadRecords at the given index.
    • getShuffleWriteList

      List<Double> getShuffleWriteList()
      repeated double shuffle_write = 12;
      Returns:
      A list containing the shuffleWrite.
    • getShuffleWriteCount

      int getShuffleWriteCount()
      repeated double shuffle_write = 12;
      Returns:
      The count of shuffleWrite.
    • getShuffleWrite

      double getShuffleWrite(int index)
      repeated double shuffle_write = 12;
      Parameters:
      index - The index of the element to return.
      Returns:
      The shuffleWrite at the given index.
    • getShuffleWriteRecordsList

      List<Double> getShuffleWriteRecordsList()
      repeated double shuffle_write_records = 13;
      Returns:
      A list containing the shuffleWriteRecords.
    • getShuffleWriteRecordsCount

      int getShuffleWriteRecordsCount()
      repeated double shuffle_write_records = 13;
      Returns:
      The count of shuffleWriteRecords.
    • getShuffleWriteRecords

      double getShuffleWriteRecords(int index)
      repeated double shuffle_write_records = 13;
      Parameters:
      index - The index of the element to return.
      Returns:
      The shuffleWriteRecords at the given index.
    • getMemoryBytesSpilledList

      List<Double> getMemoryBytesSpilledList()
      repeated double memory_bytes_spilled = 14;
      Returns:
      A list containing the memoryBytesSpilled.
    • getMemoryBytesSpilledCount

      int getMemoryBytesSpilledCount()
      repeated double memory_bytes_spilled = 14;
      Returns:
      The count of memoryBytesSpilled.
    • getMemoryBytesSpilled

      double getMemoryBytesSpilled(int index)
      repeated double memory_bytes_spilled = 14;
      Parameters:
      index - The index of the element to return.
      Returns:
      The memoryBytesSpilled at the given index.
    • getDiskBytesSpilledList

      List<Double> getDiskBytesSpilledList()
      repeated double disk_bytes_spilled = 15;
      Returns:
      A list containing the diskBytesSpilled.
    • getDiskBytesSpilledCount

      int getDiskBytesSpilledCount()
      repeated double disk_bytes_spilled = 15;
      Returns:
      The count of diskBytesSpilled.
    • getDiskBytesSpilled

      double getDiskBytesSpilled(int index)
      repeated double disk_bytes_spilled = 15;
      Parameters:
      index - The index of the element to return.
      Returns:
      The diskBytesSpilled at the given index.
    • hasPeakMemoryMetrics

      boolean hasPeakMemoryMetrics()
      .org.apache.spark.status.protobuf.ExecutorPeakMetricsDistributions peak_memory_metrics = 16;
      Returns:
      Whether the peakMemoryMetrics field is set.
    • getPeakMemoryMetrics

      .org.apache.spark.status.protobuf.ExecutorPeakMetricsDistributions peak_memory_metrics = 16;
      Returns:
      The peakMemoryMetrics.
    • getPeakMemoryMetricsOrBuilder

      .org.apache.spark.status.protobuf.ExecutorPeakMetricsDistributions peak_memory_metrics = 16;