public static interface StoreTypes.StageDataOrBuilder
extends com.google.protobuf.MessageOrBuilder
Modifier and Type | Method and Description |
---|---|
boolean |
containsExecutorSummary(String key)
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46; |
boolean |
containsKilledTasksSummary(String key)
map<string, int32> killed_tasks_summary = 48; |
boolean |
containsTasks(long key)
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45; |
StoreTypes.AccumulableInfo |
getAccumulatorUpdates(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44; |
int |
getAccumulatorUpdatesCount()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44; |
java.util.List<StoreTypes.AccumulableInfo> |
getAccumulatorUpdatesList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44; |
StoreTypes.AccumulableInfoOrBuilder |
getAccumulatorUpdatesOrBuilder(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44; |
java.util.List<? extends StoreTypes.AccumulableInfoOrBuilder> |
getAccumulatorUpdatesOrBuilderList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44; |
int |
getAttemptId()
int32 attempt_id = 3; |
long |
getCompletionTime()
optional int64 completion_time = 12; |
String |
getDescription()
optional string description = 40; |
com.google.protobuf.ByteString |
getDescriptionBytes()
optional string description = 40; |
String |
getDetails()
optional string details = 41; |
com.google.protobuf.ByteString |
getDetailsBytes()
optional string details = 41; |
long |
getDiskBytesSpilled()
int64 disk_bytes_spilled = 22; |
long |
getExecutorCpuTime()
int64 executor_cpu_time = 17; |
long |
getExecutorDeserializeCpuTime()
int64 executor_deserialize_cpu_time = 15; |
long |
getExecutorDeserializeTime()
int64 executor_deserialize_time = 14; |
StoreTypes.ExecutorMetricsDistributions |
getExecutorMetricsDistributions()
optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52; |
StoreTypes.ExecutorMetricsDistributionsOrBuilder |
getExecutorMetricsDistributionsOrBuilder()
optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52; |
long |
getExecutorRunTime()
int64 executor_run_time = 16; |
java.util.Map<String,StoreTypes.ExecutorStageSummary> |
getExecutorSummary()
Deprecated.
|
int |
getExecutorSummaryCount()
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46; |
java.util.Map<String,StoreTypes.ExecutorStageSummary> |
getExecutorSummaryMap()
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46; |
StoreTypes.ExecutorStageSummary |
getExecutorSummaryOrDefault(String key,
StoreTypes.ExecutorStageSummary defaultValue)
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46; |
StoreTypes.ExecutorStageSummary |
getExecutorSummaryOrThrow(String key)
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46; |
String |
getFailureReason()
optional string failure_reason = 13; |
com.google.protobuf.ByteString |
getFailureReasonBytes()
optional string failure_reason = 13; |
long |
getFirstTaskLaunchedTime()
optional int64 first_task_launched_time = 11; |
long |
getInputBytes()
int64 input_bytes = 24; |
long |
getInputRecords()
int64 input_records = 25; |
boolean |
getIsShufflePushEnabled()
bool is_shuffle_push_enabled = 63; |
long |
getJvmGcTime()
int64 jvm_gc_time = 19; |
java.util.Map<String,Integer> |
getKilledTasksSummary()
Deprecated.
|
int |
getKilledTasksSummaryCount()
map<string, int32> killed_tasks_summary = 48; |
java.util.Map<String,Integer> |
getKilledTasksSummaryMap()
map<string, int32> killed_tasks_summary = 48; |
int |
getKilledTasksSummaryOrDefault(String key,
int defaultValue)
map<string, int32> killed_tasks_summary = 48; |
int |
getKilledTasksSummaryOrThrow(String key)
map<string, int32> killed_tasks_summary = 48; |
long |
getMemoryBytesSpilled()
int64 memory_bytes_spilled = 21; |
String |
getName()
optional string name = 39; |
com.google.protobuf.ByteString |
getNameBytes()
optional string name = 39; |
int |
getNumActiveTasks()
int32 num_active_tasks = 5; |
int |
getNumCompletedIndices()
int32 num_completed_indices = 9; |
int |
getNumCompleteTasks()
int32 num_complete_tasks = 6; |
int |
getNumFailedTasks()
int32 num_failed_tasks = 7; |
int |
getNumKilledTasks()
int32 num_killed_tasks = 8; |
int |
getNumTasks()
int32 num_tasks = 4; |
long |
getOutputBytes()
int64 output_bytes = 26; |
long |
getOutputRecords()
int64 output_records = 27; |
long |
getPeakExecutionMemory()
int64 peak_execution_memory = 23; |
StoreTypes.ExecutorMetrics |
getPeakExecutorMetrics()
optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50; |
StoreTypes.ExecutorMetricsOrBuilder |
getPeakExecutorMetricsOrBuilder()
optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50; |
long |
getRddIds(int index)
repeated int64 rdd_ids = 43; |
int |
getRddIdsCount()
repeated int64 rdd_ids = 43; |
java.util.List<Long> |
getRddIdsList()
repeated int64 rdd_ids = 43; |
int |
getResourceProfileId()
int32 resource_profile_id = 49; |
long |
getResultSerializationTime()
int64 result_serialization_time = 20; |
long |
getResultSize()
int64 result_size = 18; |
String |
getSchedulingPool()
optional string scheduling_pool = 42; |
com.google.protobuf.ByteString |
getSchedulingPoolBytes()
optional string scheduling_pool = 42; |
long |
getShuffleCorruptMergedBlockChunks()
int64 shuffle_corrupt_merged_block_chunks = 53; |
long |
getShuffleFetchWaitTime()
int64 shuffle_fetch_wait_time = 30; |
long |
getShuffleLocalBlocksFetched()
int64 shuffle_local_blocks_fetched = 29; |
long |
getShuffleLocalBytesRead()
int64 shuffle_local_bytes_read = 33; |
long |
getShuffleMergedFetchFallbackCount()
int64 shuffle_merged_fetch_fallback_count = 54; |
long |
getShuffleMergedLocalBlocksFetched()
int64 shuffle_merged_local_blocks_fetched = 56; |
long |
getShuffleMergedLocalBytesRead()
int64 shuffle_merged_local_bytes_read = 60; |
long |
getShuffleMergedLocalChunksFetched()
int64 shuffle_merged_local_chunks_fetched = 58; |
long |
getShuffleMergedRemoteBlocksFetched()
int64 shuffle_merged_remote_blocks_fetched = 55; |
long |
getShuffleMergedRemoteBytesRead()
int64 shuffle_merged_remote_bytes_read = 59; |
long |
getShuffleMergedRemoteChunksFetched()
int64 shuffle_merged_remote_chunks_fetched = 57; |
long |
getShuffleMergedRemoteReqsDuration()
int64 shuffle_merged_remote_reqs_duration = 62; |
int |
getShuffleMergersCount()
int32 shuffle_mergers_count = 64; |
long |
getShuffleReadBytes()
int64 shuffle_read_bytes = 34; |
long |
getShuffleReadRecords()
int64 shuffle_read_records = 35; |
long |
getShuffleRemoteBlocksFetched()
int64 shuffle_remote_blocks_fetched = 28; |
long |
getShuffleRemoteBytesRead()
int64 shuffle_remote_bytes_read = 31; |
long |
getShuffleRemoteBytesReadToDisk()
int64 shuffle_remote_bytes_read_to_disk = 32; |
long |
getShuffleRemoteReqsDuration()
int64 shuffle_remote_reqs_duration = 61; |
long |
getShuffleWriteBytes()
int64 shuffle_write_bytes = 36; |
long |
getShuffleWriteRecords()
int64 shuffle_write_records = 38; |
long |
getShuffleWriteTime()
int64 shuffle_write_time = 37; |
StoreTypes.SpeculationStageSummary |
getSpeculationSummary()
optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47; |
StoreTypes.SpeculationStageSummaryOrBuilder |
getSpeculationSummaryOrBuilder()
optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47; |
long |
getStageId()
int64 stage_id = 2; |
StoreTypes.StageStatus |
getStatus()
.org.apache.spark.status.protobuf.StageStatus status = 1; |
int |
getStatusValue()
.org.apache.spark.status.protobuf.StageStatus status = 1; |
long |
getSubmissionTime()
optional int64 submission_time = 10; |
StoreTypes.TaskMetricDistributions |
getTaskMetricsDistributions()
optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51; |
StoreTypes.TaskMetricDistributionsOrBuilder |
getTaskMetricsDistributionsOrBuilder()
optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51; |
java.util.Map<Long,StoreTypes.TaskData> |
getTasks()
Deprecated.
|
int |
getTasksCount()
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45; |
java.util.Map<Long,StoreTypes.TaskData> |
getTasksMap()
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45; |
StoreTypes.TaskData |
getTasksOrDefault(long key,
StoreTypes.TaskData defaultValue)
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45; |
StoreTypes.TaskData |
getTasksOrThrow(long key)
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45; |
boolean |
hasCompletionTime()
optional int64 completion_time = 12; |
boolean |
hasDescription()
optional string description = 40; |
boolean |
hasDetails()
optional string details = 41; |
boolean |
hasExecutorMetricsDistributions()
optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52; |
boolean |
hasFailureReason()
optional string failure_reason = 13; |
boolean |
hasFirstTaskLaunchedTime()
optional int64 first_task_launched_time = 11; |
boolean |
hasName()
optional string name = 39; |
boolean |
hasPeakExecutorMetrics()
optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50; |
boolean |
hasSchedulingPool()
optional string scheduling_pool = 42; |
boolean |
hasSpeculationSummary()
optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47; |
boolean |
hasSubmissionTime()
optional int64 submission_time = 10; |
boolean |
hasTaskMetricsDistributions()
optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51; |
findInitializationErrors, getAllFields, getDefaultInstanceForType, getDescriptorForType, getField, getInitializationErrorString, getOneofFieldDescriptor, getRepeatedField, getRepeatedFieldCount, getUnknownFields, hasField, hasOneof
int getStatusValue()
.org.apache.spark.status.protobuf.StageStatus status = 1;
StoreTypes.StageStatus getStatus()
.org.apache.spark.status.protobuf.StageStatus status = 1;
long getStageId()
int64 stage_id = 2;
int getAttemptId()
int32 attempt_id = 3;
int getNumTasks()
int32 num_tasks = 4;
int getNumActiveTasks()
int32 num_active_tasks = 5;
int getNumCompleteTasks()
int32 num_complete_tasks = 6;
int getNumFailedTasks()
int32 num_failed_tasks = 7;
int getNumKilledTasks()
int32 num_killed_tasks = 8;
int getNumCompletedIndices()
int32 num_completed_indices = 9;
boolean hasSubmissionTime()
optional int64 submission_time = 10;
long getSubmissionTime()
optional int64 submission_time = 10;
boolean hasFirstTaskLaunchedTime()
optional int64 first_task_launched_time = 11;
long getFirstTaskLaunchedTime()
optional int64 first_task_launched_time = 11;
boolean hasCompletionTime()
optional int64 completion_time = 12;
long getCompletionTime()
optional int64 completion_time = 12;
boolean hasFailureReason()
optional string failure_reason = 13;
String getFailureReason()
optional string failure_reason = 13;
com.google.protobuf.ByteString getFailureReasonBytes()
optional string failure_reason = 13;
long getExecutorDeserializeTime()
int64 executor_deserialize_time = 14;
long getExecutorDeserializeCpuTime()
int64 executor_deserialize_cpu_time = 15;
long getExecutorRunTime()
int64 executor_run_time = 16;
long getExecutorCpuTime()
int64 executor_cpu_time = 17;
long getResultSize()
int64 result_size = 18;
long getJvmGcTime()
int64 jvm_gc_time = 19;
long getResultSerializationTime()
int64 result_serialization_time = 20;
long getMemoryBytesSpilled()
int64 memory_bytes_spilled = 21;
long getDiskBytesSpilled()
int64 disk_bytes_spilled = 22;
long getPeakExecutionMemory()
int64 peak_execution_memory = 23;
long getInputBytes()
int64 input_bytes = 24;
long getInputRecords()
int64 input_records = 25;
long getOutputBytes()
int64 output_bytes = 26;
long getOutputRecords()
int64 output_records = 27;
long getShuffleRemoteBlocksFetched()
int64 shuffle_remote_blocks_fetched = 28;
long getShuffleLocalBlocksFetched()
int64 shuffle_local_blocks_fetched = 29;
long getShuffleFetchWaitTime()
int64 shuffle_fetch_wait_time = 30;
long getShuffleRemoteBytesRead()
int64 shuffle_remote_bytes_read = 31;
long getShuffleRemoteBytesReadToDisk()
int64 shuffle_remote_bytes_read_to_disk = 32;
long getShuffleLocalBytesRead()
int64 shuffle_local_bytes_read = 33;
long getShuffleReadBytes()
int64 shuffle_read_bytes = 34;
long getShuffleReadRecords()
int64 shuffle_read_records = 35;
long getShuffleWriteBytes()
int64 shuffle_write_bytes = 36;
long getShuffleWriteTime()
int64 shuffle_write_time = 37;
long getShuffleWriteRecords()
int64 shuffle_write_records = 38;
boolean hasName()
optional string name = 39;
String getName()
optional string name = 39;
com.google.protobuf.ByteString getNameBytes()
optional string name = 39;
boolean hasDescription()
optional string description = 40;
String getDescription()
optional string description = 40;
com.google.protobuf.ByteString getDescriptionBytes()
optional string description = 40;
boolean hasDetails()
optional string details = 41;
String getDetails()
optional string details = 41;
com.google.protobuf.ByteString getDetailsBytes()
optional string details = 41;
boolean hasSchedulingPool()
optional string scheduling_pool = 42;
String getSchedulingPool()
optional string scheduling_pool = 42;
com.google.protobuf.ByteString getSchedulingPoolBytes()
optional string scheduling_pool = 42;
java.util.List<Long> getRddIdsList()
repeated int64 rdd_ids = 43;
int getRddIdsCount()
repeated int64 rdd_ids = 43;
long getRddIds(int index)
repeated int64 rdd_ids = 43;
index
- The index of the element to return.java.util.List<StoreTypes.AccumulableInfo> getAccumulatorUpdatesList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
StoreTypes.AccumulableInfo getAccumulatorUpdates(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
int getAccumulatorUpdatesCount()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
java.util.List<? extends StoreTypes.AccumulableInfoOrBuilder> getAccumulatorUpdatesOrBuilderList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
StoreTypes.AccumulableInfoOrBuilder getAccumulatorUpdatesOrBuilder(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 44;
int getTasksCount()
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
boolean containsTasks(long key)
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
@Deprecated java.util.Map<Long,StoreTypes.TaskData> getTasks()
getTasksMap()
instead.java.util.Map<Long,StoreTypes.TaskData> getTasksMap()
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
StoreTypes.TaskData getTasksOrDefault(long key, StoreTypes.TaskData defaultValue)
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
StoreTypes.TaskData getTasksOrThrow(long key)
map<int64, .org.apache.spark.status.protobuf.TaskData> tasks = 45;
int getExecutorSummaryCount()
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
boolean containsExecutorSummary(String key)
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
@Deprecated java.util.Map<String,StoreTypes.ExecutorStageSummary> getExecutorSummary()
getExecutorSummaryMap()
instead.java.util.Map<String,StoreTypes.ExecutorStageSummary> getExecutorSummaryMap()
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
StoreTypes.ExecutorStageSummary getExecutorSummaryOrDefault(String key, StoreTypes.ExecutorStageSummary defaultValue)
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
StoreTypes.ExecutorStageSummary getExecutorSummaryOrThrow(String key)
map<string, .org.apache.spark.status.protobuf.ExecutorStageSummary> executor_summary = 46;
boolean hasSpeculationSummary()
optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47;
StoreTypes.SpeculationStageSummary getSpeculationSummary()
optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47;
StoreTypes.SpeculationStageSummaryOrBuilder getSpeculationSummaryOrBuilder()
optional .org.apache.spark.status.protobuf.SpeculationStageSummary speculation_summary = 47;
int getKilledTasksSummaryCount()
map<string, int32> killed_tasks_summary = 48;
boolean containsKilledTasksSummary(String key)
map<string, int32> killed_tasks_summary = 48;
@Deprecated java.util.Map<String,Integer> getKilledTasksSummary()
getKilledTasksSummaryMap()
instead.java.util.Map<String,Integer> getKilledTasksSummaryMap()
map<string, int32> killed_tasks_summary = 48;
int getKilledTasksSummaryOrDefault(String key, int defaultValue)
map<string, int32> killed_tasks_summary = 48;
int getKilledTasksSummaryOrThrow(String key)
map<string, int32> killed_tasks_summary = 48;
int getResourceProfileId()
int32 resource_profile_id = 49;
boolean hasPeakExecutorMetrics()
optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50;
StoreTypes.ExecutorMetrics getPeakExecutorMetrics()
optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50;
StoreTypes.ExecutorMetricsOrBuilder getPeakExecutorMetricsOrBuilder()
optional .org.apache.spark.status.protobuf.ExecutorMetrics peak_executor_metrics = 50;
boolean hasTaskMetricsDistributions()
optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51;
StoreTypes.TaskMetricDistributions getTaskMetricsDistributions()
optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51;
StoreTypes.TaskMetricDistributionsOrBuilder getTaskMetricsDistributionsOrBuilder()
optional .org.apache.spark.status.protobuf.TaskMetricDistributions task_metrics_distributions = 51;
boolean hasExecutorMetricsDistributions()
optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52;
StoreTypes.ExecutorMetricsDistributions getExecutorMetricsDistributions()
optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52;
StoreTypes.ExecutorMetricsDistributionsOrBuilder getExecutorMetricsDistributionsOrBuilder()
optional .org.apache.spark.status.protobuf.ExecutorMetricsDistributions executor_metrics_distributions = 52;
long getShuffleCorruptMergedBlockChunks()
int64 shuffle_corrupt_merged_block_chunks = 53;
long getShuffleMergedFetchFallbackCount()
int64 shuffle_merged_fetch_fallback_count = 54;
long getShuffleMergedRemoteBlocksFetched()
int64 shuffle_merged_remote_blocks_fetched = 55;
long getShuffleMergedLocalBlocksFetched()
int64 shuffle_merged_local_blocks_fetched = 56;
long getShuffleMergedRemoteChunksFetched()
int64 shuffle_merged_remote_chunks_fetched = 57;
long getShuffleMergedLocalChunksFetched()
int64 shuffle_merged_local_chunks_fetched = 58;
long getShuffleMergedRemoteBytesRead()
int64 shuffle_merged_remote_bytes_read = 59;
long getShuffleMergedLocalBytesRead()
int64 shuffle_merged_local_bytes_read = 60;
long getShuffleRemoteReqsDuration()
int64 shuffle_remote_reqs_duration = 61;
long getShuffleMergedRemoteReqsDuration()
int64 shuffle_merged_remote_reqs_duration = 62;
boolean getIsShufflePushEnabled()
bool is_shuffle_push_enabled = 63;
int getShuffleMergersCount()
int32 shuffle_mergers_count = 64;