Interface StoreTypes.ShuffleReadMetricsOrBuilder

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

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

    • getRemoteBlocksFetched

      long getRemoteBlocksFetched()
      int64 remote_blocks_fetched = 1;
      Returns:
      The remoteBlocksFetched.
    • getLocalBlocksFetched

      long getLocalBlocksFetched()
      int64 local_blocks_fetched = 2;
      Returns:
      The localBlocksFetched.
    • getFetchWaitTime

      long getFetchWaitTime()
      int64 fetch_wait_time = 3;
      Returns:
      The fetchWaitTime.
    • getRemoteBytesRead

      long getRemoteBytesRead()
      int64 remote_bytes_read = 4;
      Returns:
      The remoteBytesRead.
    • getRemoteBytesReadToDisk

      long getRemoteBytesReadToDisk()
      int64 remote_bytes_read_to_disk = 5;
      Returns:
      The remoteBytesReadToDisk.
    • getLocalBytesRead

      long getLocalBytesRead()
      int64 local_bytes_read = 6;
      Returns:
      The localBytesRead.
    • getRecordsRead

      long getRecordsRead()
      int64 records_read = 7;
      Returns:
      The recordsRead.
    • getRemoteReqsDuration

      long getRemoteReqsDuration()
      int64 remote_reqs_duration = 8;
      Returns:
      The remoteReqsDuration.
    • hasShufflePushReadMetrics

      boolean hasShufflePushReadMetrics()
      .org.apache.spark.status.protobuf.ShufflePushReadMetrics shuffle_push_read_metrics = 9;
      Returns:
      Whether the shufflePushReadMetrics field is set.
    • getShufflePushReadMetrics

      StoreTypes.ShufflePushReadMetrics getShufflePushReadMetrics()
      .org.apache.spark.status.protobuf.ShufflePushReadMetrics shuffle_push_read_metrics = 9;
      Returns:
      The shufflePushReadMetrics.
    • getShufflePushReadMetricsOrBuilder

      StoreTypes.ShufflePushReadMetricsOrBuilder getShufflePushReadMetricsOrBuilder()
      .org.apache.spark.status.protobuf.ShufflePushReadMetrics shuffle_push_read_metrics = 9;