public static interface StoreTypes.TaskDataWrapperOrBuilder
extends com.google.protobuf.MessageOrBuilder
Modifier and Type | Method and Description |
---|---|
StoreTypes.AccumulableInfo |
getAccumulatorUpdates(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13; |
int |
getAccumulatorUpdatesCount()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13; |
java.util.List<StoreTypes.AccumulableInfo> |
getAccumulatorUpdatesList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13; |
StoreTypes.AccumulableInfoOrBuilder |
getAccumulatorUpdatesOrBuilder(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13; |
java.util.List<? extends StoreTypes.AccumulableInfoOrBuilder> |
getAccumulatorUpdatesOrBuilderList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13; |
int |
getAttempt()
int32 attempt = 3; |
long |
getDiskBytesSpilled()
int64 disk_bytes_spilled = 24; |
long |
getDuration()
int64 duration = 7; |
String |
getErrorMessage()
optional string error_message = 14; |
com.google.protobuf.ByteString |
getErrorMessageBytes()
optional string error_message = 14; |
long |
getExecutorCpuTime()
int64 executor_cpu_time = 19; |
long |
getExecutorDeserializeCpuTime()
int64 executor_deserialize_cpu_time = 17; |
long |
getExecutorDeserializeTime()
int64 executor_deserialize_time = 16; |
String |
getExecutorId()
optional string executor_id = 8; |
com.google.protobuf.ByteString |
getExecutorIdBytes()
optional string executor_id = 8; |
long |
getExecutorRunTime()
int64 executor_run_time = 18; |
boolean |
getHasMetrics()
bool has_metrics = 15; |
String |
getHost()
optional string host = 9; |
com.google.protobuf.ByteString |
getHostBytes()
optional string host = 9; |
int |
getIndex()
int32 index = 2; |
long |
getInputBytesRead()
int64 input_bytes_read = 26; |
long |
getInputRecordsRead()
int64 input_records_read = 27; |
long |
getJvmGcTime()
int64 jvm_gc_time = 21; |
long |
getLaunchTime()
int64 launch_time = 5; |
long |
getMemoryBytesSpilled()
int64 memory_bytes_spilled = 23; |
long |
getOutputBytesWritten()
int64 output_bytes_written = 28; |
long |
getOutputRecordsWritten()
int64 output_records_written = 29; |
int |
getPartitionId()
int32 partition_id = 4; |
long |
getPeakExecutionMemory()
int64 peak_execution_memory = 25; |
long |
getResultFetchStart()
int64 result_fetch_start = 6; |
long |
getResultSerializationTime()
int64 result_serialization_time = 22; |
long |
getResultSize()
int64 result_size = 20; |
long |
getShuffleBytesWritten()
int64 shuffle_bytes_written = 37; |
long |
getShuffleCorruptMergedBlockChunks()
int64 shuffle_corrupt_merged_block_chunks = 42; |
long |
getShuffleFetchWaitTime()
int64 shuffle_fetch_wait_time = 32; |
long |
getShuffleLocalBlocksFetched()
int64 shuffle_local_blocks_fetched = 31; |
long |
getShuffleLocalBytesRead()
int64 shuffle_local_bytes_read = 35; |
long |
getShuffleMergedFetchFallbackCount()
int64 shuffle_merged_fetch_fallback_count = 43; |
long |
getShuffleMergedLocalBlocksFetched()
int64 shuffle_merged_local_blocks_fetched = 45; |
long |
getShuffleMergedLocalBytesRead()
int64 shuffle_merged_local_bytes_read = 49; |
long |
getShuffleMergedLocalChunksFetched()
int64 shuffle_merged_local_chunks_fetched = 47; |
long |
getShuffleMergedRemoteBlocksFetched()
int64 shuffle_merged_remote_blocks_fetched = 44; |
long |
getShuffleMergedRemoteBytesRead()
int64 shuffle_merged_remote_bytes_read = 48; |
long |
getShuffleMergedRemoteChunksFetched()
int64 shuffle_merged_remote_chunks_fetched = 46; |
long |
getShuffleMergedRemoteReqDuration()
int64 shuffle_merged_remote_req_duration = 51; |
long |
getShuffleRecordsRead()
int64 shuffle_records_read = 36; |
long |
getShuffleRecordsWritten()
int64 shuffle_records_written = 39; |
long |
getShuffleRemoteBlocksFetched()
int64 shuffle_remote_blocks_fetched = 30; |
long |
getShuffleRemoteBytesRead()
int64 shuffle_remote_bytes_read = 33; |
long |
getShuffleRemoteBytesReadToDisk()
int64 shuffle_remote_bytes_read_to_disk = 34; |
long |
getShuffleRemoteReqsDuration()
int64 shuffle_remote_reqs_duration = 50; |
long |
getShuffleWriteTime()
int64 shuffle_write_time = 38; |
boolean |
getSpeculative()
bool speculative = 12; |
int |
getStageAttemptId()
int32 stage_attempt_id = 41; |
long |
getStageId()
int64 stage_id = 40; |
String |
getStatus()
optional string status = 10; |
com.google.protobuf.ByteString |
getStatusBytes()
optional string status = 10; |
long |
getTaskId()
int64 task_id = 1; |
String |
getTaskLocality()
optional string task_locality = 11; |
com.google.protobuf.ByteString |
getTaskLocalityBytes()
optional string task_locality = 11; |
boolean |
hasErrorMessage()
optional string error_message = 14; |
boolean |
hasExecutorId()
optional string executor_id = 8; |
boolean |
hasHost()
optional string host = 9; |
boolean |
hasStatus()
optional string status = 10; |
boolean |
hasTaskLocality()
optional string task_locality = 11; |
findInitializationErrors, getAllFields, getDefaultInstanceForType, getDescriptorForType, getField, getInitializationErrorString, getOneofFieldDescriptor, getRepeatedField, getRepeatedFieldCount, getUnknownFields, hasField, hasOneof
long getTaskId()
int64 task_id = 1;
int getIndex()
int32 index = 2;
int getAttempt()
int32 attempt = 3;
int getPartitionId()
int32 partition_id = 4;
long getLaunchTime()
int64 launch_time = 5;
long getResultFetchStart()
int64 result_fetch_start = 6;
long getDuration()
int64 duration = 7;
boolean hasExecutorId()
optional string executor_id = 8;
String getExecutorId()
optional string executor_id = 8;
com.google.protobuf.ByteString getExecutorIdBytes()
optional string executor_id = 8;
boolean hasHost()
optional string host = 9;
String getHost()
optional string host = 9;
com.google.protobuf.ByteString getHostBytes()
optional string host = 9;
boolean hasStatus()
optional string status = 10;
String getStatus()
optional string status = 10;
com.google.protobuf.ByteString getStatusBytes()
optional string status = 10;
boolean hasTaskLocality()
optional string task_locality = 11;
String getTaskLocality()
optional string task_locality = 11;
com.google.protobuf.ByteString getTaskLocalityBytes()
optional string task_locality = 11;
boolean getSpeculative()
bool speculative = 12;
java.util.List<StoreTypes.AccumulableInfo> getAccumulatorUpdatesList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
StoreTypes.AccumulableInfo getAccumulatorUpdates(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
int getAccumulatorUpdatesCount()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
java.util.List<? extends StoreTypes.AccumulableInfoOrBuilder> getAccumulatorUpdatesOrBuilderList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
StoreTypes.AccumulableInfoOrBuilder getAccumulatorUpdatesOrBuilder(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
boolean hasErrorMessage()
optional string error_message = 14;
String getErrorMessage()
optional string error_message = 14;
com.google.protobuf.ByteString getErrorMessageBytes()
optional string error_message = 14;
boolean getHasMetrics()
bool has_metrics = 15;
long getExecutorDeserializeTime()
int64 executor_deserialize_time = 16;
long getExecutorDeserializeCpuTime()
int64 executor_deserialize_cpu_time = 17;
long getExecutorRunTime()
int64 executor_run_time = 18;
long getExecutorCpuTime()
int64 executor_cpu_time = 19;
long getResultSize()
int64 result_size = 20;
long getJvmGcTime()
int64 jvm_gc_time = 21;
long getResultSerializationTime()
int64 result_serialization_time = 22;
long getMemoryBytesSpilled()
int64 memory_bytes_spilled = 23;
long getDiskBytesSpilled()
int64 disk_bytes_spilled = 24;
long getPeakExecutionMemory()
int64 peak_execution_memory = 25;
long getInputBytesRead()
int64 input_bytes_read = 26;
long getInputRecordsRead()
int64 input_records_read = 27;
long getOutputBytesWritten()
int64 output_bytes_written = 28;
long getOutputRecordsWritten()
int64 output_records_written = 29;
long getShuffleRemoteBlocksFetched()
int64 shuffle_remote_blocks_fetched = 30;
long getShuffleLocalBlocksFetched()
int64 shuffle_local_blocks_fetched = 31;
long getShuffleFetchWaitTime()
int64 shuffle_fetch_wait_time = 32;
long getShuffleRemoteBytesRead()
int64 shuffle_remote_bytes_read = 33;
long getShuffleRemoteBytesReadToDisk()
int64 shuffle_remote_bytes_read_to_disk = 34;
long getShuffleLocalBytesRead()
int64 shuffle_local_bytes_read = 35;
long getShuffleRecordsRead()
int64 shuffle_records_read = 36;
long getShuffleBytesWritten()
int64 shuffle_bytes_written = 37;
long getShuffleWriteTime()
int64 shuffle_write_time = 38;
long getShuffleRecordsWritten()
int64 shuffle_records_written = 39;
long getStageId()
int64 stage_id = 40;
int getStageAttemptId()
int32 stage_attempt_id = 41;
long getShuffleCorruptMergedBlockChunks()
int64 shuffle_corrupt_merged_block_chunks = 42;
long getShuffleMergedFetchFallbackCount()
int64 shuffle_merged_fetch_fallback_count = 43;
long getShuffleMergedRemoteBlocksFetched()
int64 shuffle_merged_remote_blocks_fetched = 44;
long getShuffleMergedLocalBlocksFetched()
int64 shuffle_merged_local_blocks_fetched = 45;
long getShuffleMergedRemoteChunksFetched()
int64 shuffle_merged_remote_chunks_fetched = 46;
long getShuffleMergedLocalChunksFetched()
int64 shuffle_merged_local_chunks_fetched = 47;
long getShuffleMergedRemoteBytesRead()
int64 shuffle_merged_remote_bytes_read = 48;
long getShuffleMergedLocalBytesRead()
int64 shuffle_merged_local_bytes_read = 49;
long getShuffleRemoteReqsDuration()
int64 shuffle_remote_reqs_duration = 50;
long getShuffleMergedRemoteReqDuration()
int64 shuffle_merged_remote_req_duration = 51;