Interface StoreTypes.StageDataOrBuilder

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

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

    • getStatusValue

      int getStatusValue()
      .org.apache.spark.status.protobuf.StageStatus status = 1;
      Returns:
      The enum numeric value on the wire for status.
    • getStatus

      .org.apache.spark.status.protobuf.StageStatus status = 1;
      Returns:
      The status.
    • getStageId

      long getStageId()
      int64 stage_id = 2;
      Returns:
      The stageId.
    • getAttemptId

      int getAttemptId()
      int32 attempt_id = 3;
      Returns:
      The attemptId.
    • getNumTasks

      int getNumTasks()
      int32 num_tasks = 4;
      Returns:
      The numTasks.
    • getNumActiveTasks

      int getNumActiveTasks()
      int32 num_active_tasks = 5;
      Returns:
      The numActiveTasks.
    • getNumCompleteTasks

      int getNumCompleteTasks()
      int32 num_complete_tasks = 6;
      Returns:
      The numCompleteTasks.
    • getNumFailedTasks

      int getNumFailedTasks()
      int32 num_failed_tasks = 7;
      Returns:
      The numFailedTasks.
    • getNumKilledTasks

      int getNumKilledTasks()
      int32 num_killed_tasks = 8;
      Returns:
      The numKilledTasks.
    • getNumCompletedIndices

      int getNumCompletedIndices()
      int32 num_completed_indices = 9;
      Returns:
      The numCompletedIndices.
    • hasSubmissionTime

      boolean hasSubmissionTime()
      optional int64 submission_time = 10;
      Returns:
      Whether the submissionTime field is set.
    • getSubmissionTime

      long getSubmissionTime()
      optional int64 submission_time = 10;
      Returns:
      The submissionTime.
    • hasFirstTaskLaunchedTime

      boolean hasFirstTaskLaunchedTime()
      optional int64 first_task_launched_time = 11;
      Returns:
      Whether the firstTaskLaunchedTime field is set.
    • getFirstTaskLaunchedTime

      long getFirstTaskLaunchedTime()
      optional int64 first_task_launched_time = 11;
      Returns:
      The firstTaskLaunchedTime.
    • hasCompletionTime

      boolean hasCompletionTime()
      optional int64 completion_time = 12;
      Returns:
      Whether the completionTime field is set.
    • getCompletionTime

      long getCompletionTime()
      optional int64 completion_time = 12;
      Returns:
      The completionTime.
    • hasFailureReason

      boolean hasFailureReason()
      optional string failure_reason = 13;
      Returns:
      Whether the failureReason field is set.
    • getFailureReason

      String getFailureReason()
      optional string failure_reason = 13;
      Returns:
      The failureReason.
    • getFailureReasonBytes

      com.google.protobuf.ByteString getFailureReasonBytes()
      optional string failure_reason = 13;
      Returns:
      The bytes for failureReason.
    • getExecutorDeserializeTime

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

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

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

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

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

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

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

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

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

      long getPeakExecutionMemory()
      int64 peak_execution_memory = 23;
      Returns:
      The peakExecutionMemory.
    • getInputBytes

      long getInputBytes()
      int64 input_bytes = 24;
      Returns:
      The inputBytes.
    • getInputRecords

      long getInputRecords()
      int64 input_records = 25;
      Returns:
      The inputRecords.
    • getOutputBytes

      long getOutputBytes()
      int64 output_bytes = 26;
      Returns:
      The outputBytes.
    • getOutputRecords

      long getOutputRecords()
      int64 output_records = 27;
      Returns:
      The outputRecords.
    • getShuffleRemoteBlocksFetched

      long getShuffleRemoteBlocksFetched()
      int64 shuffle_remote_blocks_fetched = 28;
      Returns:
      The shuffleRemoteBlocksFetched.
    • getShuffleLocalBlocksFetched

      long getShuffleLocalBlocksFetched()
      int64 shuffle_local_blocks_fetched = 29;
      Returns:
      The shuffleLocalBlocksFetched.
    • getShuffleFetchWaitTime

      long getShuffleFetchWaitTime()
      int64 shuffle_fetch_wait_time = 30;
      Returns:
      The shuffleFetchWaitTime.
    • getShuffleRemoteBytesRead

      long getShuffleRemoteBytesRead()
      int64 shuffle_remote_bytes_read = 31;
      Returns:
      The shuffleRemoteBytesRead.
    • getShuffleRemoteBytesReadToDisk

      long getShuffleRemoteBytesReadToDisk()
      int64 shuffle_remote_bytes_read_to_disk = 32;
      Returns:
      The shuffleRemoteBytesReadToDisk.
    • getShuffleLocalBytesRead

      long getShuffleLocalBytesRead()
      int64 shuffle_local_bytes_read = 33;
      Returns:
      The shuffleLocalBytesRead.
    • getShuffleReadBytes

      long getShuffleReadBytes()
      int64 shuffle_read_bytes = 34;
      Returns:
      The shuffleReadBytes.
    • getShuffleReadRecords

      long getShuffleReadRecords()
      int64 shuffle_read_records = 35;
      Returns:
      The shuffleReadRecords.
    • getShuffleWriteBytes

      long getShuffleWriteBytes()
      int64 shuffle_write_bytes = 36;
      Returns:
      The shuffleWriteBytes.
    • getShuffleWriteTime

      long getShuffleWriteTime()
      int64 shuffle_write_time = 37;
      Returns:
      The shuffleWriteTime.
    • getShuffleWriteRecords

      long getShuffleWriteRecords()
      int64 shuffle_write_records = 38;
      Returns:
      The shuffleWriteRecords.
    • hasName

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

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

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

      boolean hasDescription()
      optional string description = 40;
      Returns:
      Whether the description field is set.
    • getDescription

      String getDescription()
      optional string description = 40;
      Returns:
      The description.
    • getDescriptionBytes

      com.google.protobuf.ByteString getDescriptionBytes()
      optional string description = 40;
      Returns:
      The bytes for description.
    • hasDetails

      boolean hasDetails()
      optional string details = 41;
      Returns:
      Whether the details field is set.
    • getDetails

      String getDetails()
      optional string details = 41;
      Returns:
      The details.
    • getDetailsBytes

      com.google.protobuf.ByteString getDetailsBytes()
      optional string details = 41;
      Returns:
      The bytes for details.
    • hasSchedulingPool

      boolean hasSchedulingPool()
      optional string scheduling_pool = 42;
      Returns:
      Whether the schedulingPool field is set.
    • getSchedulingPool

      String getSchedulingPool()
      optional string scheduling_pool = 42;
      Returns:
      The schedulingPool.
    • getSchedulingPoolBytes

      com.google.protobuf.ByteString getSchedulingPoolBytes()
      optional string scheduling_pool = 42;
      Returns:
      The bytes for schedulingPool.
    • getRddIdsList

      List<Long> getRddIdsList()
      repeated int64 rdd_ids = 43;
      Returns:
      A list containing the rddIds.
    • getRddIdsCount

      int getRddIdsCount()
      repeated int64 rdd_ids = 43;
      Returns:
      The count of rddIds.
    • getRddIds

      long getRddIds(int index)
      repeated int64 rdd_ids = 43;
      Parameters:
      index - The index of the element to return.
      Returns:
      The rddIds at the given index.
    • getAccumulatorUpdatesList

      List<StoreTypes.AccumulableInfo> getAccumulatorUpdatesList()
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
    • getAccumulatorUpdates

      StoreTypes.AccumulableInfo getAccumulatorUpdates(int index)
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
    • getAccumulatorUpdatesCount

      int getAccumulatorUpdatesCount()
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
    • getAccumulatorUpdatesOrBuilderList

      List<? extends StoreTypes.AccumulableInfoOrBuilder> getAccumulatorUpdatesOrBuilderList()
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
    • getAccumulatorUpdatesOrBuilder

      StoreTypes.AccumulableInfoOrBuilder getAccumulatorUpdatesOrBuilder(int index)
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
    • getTasksCount

      int getTasksCount()
      map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
    • containsTasks

      boolean containsTasks(long key)
      map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
    • getTasks

      Deprecated.
      Use getTasksMap() instead.
    • getTasksMap

      Map<Long,StoreTypes.TaskData> getTasksMap()
      map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
    • getTasksOrDefault

      StoreTypes.TaskData getTasksOrDefault(long key, StoreTypes.TaskData defaultValue)
      map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
    • getTasksOrThrow

      StoreTypes.TaskData getTasksOrThrow(long key)
      map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
    • getExecutorSummaryCount

      int getExecutorSummaryCount()
      map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
    • containsExecutorSummary

      boolean containsExecutorSummary(String key)
      map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
    • getExecutorSummary

      Deprecated.
    • getExecutorSummaryMap

      Map<String,StoreTypes.ExecutorStageSummary> getExecutorSummaryMap()
      map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
    • getExecutorSummaryOrDefault

      StoreTypes.ExecutorStageSummary getExecutorSummaryOrDefault(String key, StoreTypes.ExecutorStageSummary defaultValue)
      map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
    • getExecutorSummaryOrThrow

      StoreTypes.ExecutorStageSummary getExecutorSummaryOrThrow(String key)
      map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
    • hasSpeculationSummary

      boolean hasSpeculationSummary()
      optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47;
      Returns:
      Whether the speculationSummary field is set.
    • getSpeculationSummary

      StoreTypes.SpeculationStageSummary getSpeculationSummary()
      optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47;
      Returns:
      The speculationSummary.
    • getSpeculationSummaryOrBuilder

      StoreTypes.SpeculationStageSummaryOrBuilder getSpeculationSummaryOrBuilder()
      optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47;
    • getKilledTasksSummaryCount

      int getKilledTasksSummaryCount()
      map<string, int32> killed_tasks_summary = 48;
    • containsKilledTasksSummary

      boolean containsKilledTasksSummary(String key)
      map<string, int32> killed_tasks_summary = 48;
    • getKilledTasksSummary

      @Deprecated Map<String,Integer> getKilledTasksSummary()
      Deprecated.
    • getKilledTasksSummaryMap

      Map<String,Integer> getKilledTasksSummaryMap()
      map<string, int32> killed_tasks_summary = 48;
    • getKilledTasksSummaryOrDefault

      int getKilledTasksSummaryOrDefault(String key, int defaultValue)
      map<string, int32> killed_tasks_summary = 48;
    • getKilledTasksSummaryOrThrow

      int getKilledTasksSummaryOrThrow(String key)
      map<string, int32> killed_tasks_summary = 48;
    • getResourceProfileId

      int getResourceProfileId()
      int32 resource_profile_id = 49;
      Returns:
      The resourceProfileId.
    • hasPeakExecutorMetrics

      boolean hasPeakExecutorMetrics()
      optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50;
      Returns:
      Whether the peakExecutorMetrics field is set.
    • getPeakExecutorMetrics

      StoreTypes.ExecutorMetrics getPeakExecutorMetrics()
      optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50;
      Returns:
      The peakExecutorMetrics.
    • getPeakExecutorMetricsOrBuilder

      StoreTypes.ExecutorMetricsOrBuilder getPeakExecutorMetricsOrBuilder()
      optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50;
    • hasTaskMetricsDistributions

      boolean hasTaskMetricsDistributions()
      optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51;
      Returns:
      Whether the taskMetricsDistributions field is set.
    • getTaskMetricsDistributions

      StoreTypes.TaskMetricDistributions getTaskMetricsDistributions()
      optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51;
      Returns:
      The taskMetricsDistributions.
    • getTaskMetricsDistributionsOrBuilder

      StoreTypes.TaskMetricDistributionsOrBuilder getTaskMetricsDistributionsOrBuilder()
      optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51;
    • hasExecutorMetricsDistributions

      boolean hasExecutorMetricsDistributions()
      optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52;
      Returns:
      Whether the executorMetricsDistributions field is set.
    • getExecutorMetricsDistributions

      StoreTypes.ExecutorMetricsDistributions getExecutorMetricsDistributions()
      optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52;
      Returns:
      The executorMetricsDistributions.
    • getExecutorMetricsDistributionsOrBuilder

      StoreTypes.ExecutorMetricsDistributionsOrBuilder getExecutorMetricsDistributionsOrBuilder()
      optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52;
    • getShuffleCorruptMergedBlockChunks

      long getShuffleCorruptMergedBlockChunks()
      int64 shuffle_corrupt_merged_block_chunks = 53;
      Returns:
      The shuffleCorruptMergedBlockChunks.
    • getShuffleMergedFetchFallbackCount

      long getShuffleMergedFetchFallbackCount()
      int64 shuffle_merged_fetch_fallback_count = 54;
      Returns:
      The shuffleMergedFetchFallbackCount.
    • getShuffleMergedRemoteBlocksFetched

      long getShuffleMergedRemoteBlocksFetched()
      int64 shuffle_merged_remote_blocks_fetched = 55;
      Returns:
      The shuffleMergedRemoteBlocksFetched.
    • getShuffleMergedLocalBlocksFetched

      long getShuffleMergedLocalBlocksFetched()
      int64 shuffle_merged_local_blocks_fetched = 56;
      Returns:
      The shuffleMergedLocalBlocksFetched.
    • getShuffleMergedRemoteChunksFetched

      long getShuffleMergedRemoteChunksFetched()
      int64 shuffle_merged_remote_chunks_fetched = 57;
      Returns:
      The shuffleMergedRemoteChunksFetched.
    • getShuffleMergedLocalChunksFetched

      long getShuffleMergedLocalChunksFetched()
      int64 shuffle_merged_local_chunks_fetched = 58;
      Returns:
      The shuffleMergedLocalChunksFetched.
    • getShuffleMergedRemoteBytesRead

      long getShuffleMergedRemoteBytesRead()
      int64 shuffle_merged_remote_bytes_read = 59;
      Returns:
      The shuffleMergedRemoteBytesRead.
    • getShuffleMergedLocalBytesRead

      long getShuffleMergedLocalBytesRead()
      int64 shuffle_merged_local_bytes_read = 60;
      Returns:
      The shuffleMergedLocalBytesRead.
    • getShuffleRemoteReqsDuration

      long getShuffleRemoteReqsDuration()
      int64 shuffle_remote_reqs_duration = 61;
      Returns:
      The shuffleRemoteReqsDuration.
    • getShuffleMergedRemoteReqsDuration

      long getShuffleMergedRemoteReqsDuration()
      int64 shuffle_merged_remote_reqs_duration = 62;
      Returns:
      The shuffleMergedRemoteReqsDuration.
    • getIsShufflePushEnabled

      boolean getIsShufflePushEnabled()
      bool is_shuffle_push_enabled = 63;
      Returns:
      The isShufflePushEnabled.
    • getShuffleMergersCount

      int getShuffleMergersCount()
      int32 shuffle_mergers_count = 64;
      Returns:
      The shuffleMergersCount.