Package org.apache.spark.status.protobuf
Class StoreTypes.TaskDataWrapper
Object
com.google.protobuf.AbstractMessageLite
com.google.protobuf.AbstractMessage
com.google.protobuf.GeneratedMessageV3
org.apache.spark.status.protobuf.StoreTypes.TaskDataWrapper
- All Implemented Interfaces:
com.google.protobuf.Message
,com.google.protobuf.MessageLite
,com.google.protobuf.MessageLiteOrBuilder
,com.google.protobuf.MessageOrBuilder
,Serializable
,StoreTypes.TaskDataWrapperOrBuilder
- Enclosing class:
- StoreTypes
public static final class StoreTypes.TaskDataWrapper
extends com.google.protobuf.GeneratedMessageV3
implements StoreTypes.TaskDataWrapperOrBuilder
Protobuf type
org.apache.spark.status.protobuf.TaskDataWrapper
- See Also:
-
Nested Class Summary
Modifier and TypeClassDescriptionstatic final class
Protobuf typeorg.apache.spark.status.protobuf.TaskDataWrapper
Nested classes/interfaces inherited from class com.google.protobuf.GeneratedMessageV3
com.google.protobuf.GeneratedMessageV3.ExtendableBuilder<MessageType extends com.google.protobuf.GeneratedMessageV3.ExtendableMessage,
BuilderType extends com.google.protobuf.GeneratedMessageV3.ExtendableBuilder<MessageType, BuilderType>>, com.google.protobuf.GeneratedMessageV3.ExtendableMessage<MessageType extends com.google.protobuf.GeneratedMessageV3.ExtendableMessage>, com.google.protobuf.GeneratedMessageV3.ExtendableMessageOrBuilder<MessageType extends com.google.protobuf.GeneratedMessageV3.ExtendableMessage>, com.google.protobuf.GeneratedMessageV3.FieldAccessorTable -
Field Summary
Modifier and TypeFieldDescriptionstatic final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
static final int
-
Method Summary
Modifier and TypeMethodDescriptionboolean
getAccumulatorUpdates
(int index) repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
int
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
getAccumulatorUpdatesOrBuilder
(int index) repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
List<? extends StoreTypes.AccumulableInfoOrBuilder>
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
int
int32 attempt = 3;
static StoreTypes.TaskDataWrapper
static final com.google.protobuf.Descriptors.Descriptor
long
int64 disk_bytes_spilled = 24;
long
int64 duration = 7;
optional string error_message = 14;
com.google.protobuf.ByteString
optional string error_message = 14;
long
int64 executor_cpu_time = 19;
long
int64 executor_deserialize_cpu_time = 17;
long
int64 executor_deserialize_time = 16;
optional string executor_id = 8;
com.google.protobuf.ByteString
optional string executor_id = 8;
long
int64 executor_run_time = 18;
boolean
bool has_metrics = 15;
getHost()
optional string host = 9;
com.google.protobuf.ByteString
optional string host = 9;
int
getIndex()
int32 index = 2;
long
int64 input_bytes_read = 26;
long
int64 input_records_read = 27;
long
int64 jvm_gc_time = 21;
long
int64 launch_time = 5;
long
int64 memory_bytes_spilled = 23;
long
int64 output_bytes_written = 28;
long
int64 output_records_written = 29;
com.google.protobuf.Parser<StoreTypes.TaskDataWrapper>
int
int32 partition_id = 4;
long
int64 peak_execution_memory = 25;
long
int64 result_fetch_start = 6;
long
int64 result_serialization_time = 22;
long
int64 result_size = 20;
int
long
int64 shuffle_bytes_written = 37;
long
int64 shuffle_corrupt_merged_block_chunks = 42;
long
int64 shuffle_fetch_wait_time = 32;
long
int64 shuffle_local_blocks_fetched = 31;
long
int64 shuffle_local_bytes_read = 35;
long
int64 shuffle_merged_fetch_fallback_count = 43;
long
int64 shuffle_merged_local_blocks_fetched = 45;
long
int64 shuffle_merged_local_bytes_read = 49;
long
int64 shuffle_merged_local_chunks_fetched = 47;
long
int64 shuffle_merged_remote_blocks_fetched = 44;
long
int64 shuffle_merged_remote_bytes_read = 48;
long
int64 shuffle_merged_remote_chunks_fetched = 46;
long
int64 shuffle_merged_remote_req_duration = 51;
long
int64 shuffle_records_read = 36;
long
int64 shuffle_records_written = 39;
long
int64 shuffle_remote_blocks_fetched = 30;
long
int64 shuffle_remote_bytes_read = 33;
long
int64 shuffle_remote_bytes_read_to_disk = 34;
long
int64 shuffle_remote_reqs_duration = 50;
long
int64 shuffle_write_time = 38;
boolean
bool speculative = 12;
int
int32 stage_attempt_id = 41;
long
int64 stage_id = 40;
optional string status = 10;
com.google.protobuf.ByteString
optional string status = 10;
long
int64 task_id = 1;
optional string task_locality = 11;
com.google.protobuf.ByteString
optional string task_locality = 11;
boolean
optional string error_message = 14;
boolean
optional string executor_id = 8;
int
hashCode()
boolean
hasHost()
optional string host = 9;
boolean
optional string status = 10;
boolean
optional string task_locality = 11;
final boolean
newBuilder
(StoreTypes.TaskDataWrapper prototype) static StoreTypes.TaskDataWrapper
parseDelimitedFrom
(InputStream input) static StoreTypes.TaskDataWrapper
parseDelimitedFrom
(InputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) static StoreTypes.TaskDataWrapper
parseFrom
(byte[] data) static StoreTypes.TaskDataWrapper
parseFrom
(byte[] data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) static StoreTypes.TaskDataWrapper
parseFrom
(com.google.protobuf.ByteString data) static StoreTypes.TaskDataWrapper
parseFrom
(com.google.protobuf.ByteString data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) static StoreTypes.TaskDataWrapper
parseFrom
(com.google.protobuf.CodedInputStream input) static StoreTypes.TaskDataWrapper
parseFrom
(com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) static StoreTypes.TaskDataWrapper
parseFrom
(InputStream input) static StoreTypes.TaskDataWrapper
parseFrom
(InputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) static StoreTypes.TaskDataWrapper
parseFrom
(ByteBuffer data) static StoreTypes.TaskDataWrapper
parseFrom
(ByteBuffer data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) static com.google.protobuf.Parser<StoreTypes.TaskDataWrapper>
parser()
void
writeTo
(com.google.protobuf.CodedOutputStream output) Methods inherited from class com.google.protobuf.GeneratedMessageV3
getAllFields, getDescriptorForType, getField, getOneofFieldDescriptor, getRepeatedField, getRepeatedFieldCount, getUnknownFields, hasField, hasOneof
Methods inherited from class com.google.protobuf.AbstractMessage
findInitializationErrors, getInitializationErrorString, toString
Methods inherited from class com.google.protobuf.AbstractMessageLite
toByteArray, toByteString, writeDelimitedTo, writeTo
Methods inherited from interface com.google.protobuf.MessageLite
toByteArray, toByteString, writeDelimitedTo, writeTo
Methods inherited from interface com.google.protobuf.MessageOrBuilder
findInitializationErrors, getAllFields, getDescriptorForType, getField, getInitializationErrorString, getOneofFieldDescriptor, getRepeatedField, getRepeatedFieldCount, getUnknownFields, hasField, hasOneof
-
Field Details
-
TASK_ID_FIELD_NUMBER
public static final int TASK_ID_FIELD_NUMBER- See Also:
-
INDEX_FIELD_NUMBER
public static final int INDEX_FIELD_NUMBER- See Also:
-
ATTEMPT_FIELD_NUMBER
public static final int ATTEMPT_FIELD_NUMBER- See Also:
-
PARTITION_ID_FIELD_NUMBER
public static final int PARTITION_ID_FIELD_NUMBER- See Also:
-
LAUNCH_TIME_FIELD_NUMBER
public static final int LAUNCH_TIME_FIELD_NUMBER- See Also:
-
RESULT_FETCH_START_FIELD_NUMBER
public static final int RESULT_FETCH_START_FIELD_NUMBER- See Also:
-
DURATION_FIELD_NUMBER
public static final int DURATION_FIELD_NUMBER- See Also:
-
EXECUTOR_ID_FIELD_NUMBER
public static final int EXECUTOR_ID_FIELD_NUMBER- See Also:
-
HOST_FIELD_NUMBER
public static final int HOST_FIELD_NUMBER- See Also:
-
STATUS_FIELD_NUMBER
public static final int STATUS_FIELD_NUMBER- See Also:
-
TASK_LOCALITY_FIELD_NUMBER
public static final int TASK_LOCALITY_FIELD_NUMBER- See Also:
-
SPECULATIVE_FIELD_NUMBER
public static final int SPECULATIVE_FIELD_NUMBER- See Also:
-
ACCUMULATOR_UPDATES_FIELD_NUMBER
public static final int ACCUMULATOR_UPDATES_FIELD_NUMBER- See Also:
-
ERROR_MESSAGE_FIELD_NUMBER
public static final int ERROR_MESSAGE_FIELD_NUMBER- See Also:
-
HAS_METRICS_FIELD_NUMBER
public static final int HAS_METRICS_FIELD_NUMBER- See Also:
-
EXECUTOR_DESERIALIZE_TIME_FIELD_NUMBER
public static final int EXECUTOR_DESERIALIZE_TIME_FIELD_NUMBER- See Also:
-
EXECUTOR_DESERIALIZE_CPU_TIME_FIELD_NUMBER
public static final int EXECUTOR_DESERIALIZE_CPU_TIME_FIELD_NUMBER- See Also:
-
EXECUTOR_RUN_TIME_FIELD_NUMBER
public static final int EXECUTOR_RUN_TIME_FIELD_NUMBER- See Also:
-
EXECUTOR_CPU_TIME_FIELD_NUMBER
public static final int EXECUTOR_CPU_TIME_FIELD_NUMBER- See Also:
-
RESULT_SIZE_FIELD_NUMBER
public static final int RESULT_SIZE_FIELD_NUMBER- See Also:
-
JVM_GC_TIME_FIELD_NUMBER
public static final int JVM_GC_TIME_FIELD_NUMBER- See Also:
-
RESULT_SERIALIZATION_TIME_FIELD_NUMBER
public static final int RESULT_SERIALIZATION_TIME_FIELD_NUMBER- See Also:
-
MEMORY_BYTES_SPILLED_FIELD_NUMBER
public static final int MEMORY_BYTES_SPILLED_FIELD_NUMBER- See Also:
-
DISK_BYTES_SPILLED_FIELD_NUMBER
public static final int DISK_BYTES_SPILLED_FIELD_NUMBER- See Also:
-
PEAK_EXECUTION_MEMORY_FIELD_NUMBER
public static final int PEAK_EXECUTION_MEMORY_FIELD_NUMBER- See Also:
-
INPUT_BYTES_READ_FIELD_NUMBER
public static final int INPUT_BYTES_READ_FIELD_NUMBER- See Also:
-
INPUT_RECORDS_READ_FIELD_NUMBER
public static final int INPUT_RECORDS_READ_FIELD_NUMBER- See Also:
-
OUTPUT_BYTES_WRITTEN_FIELD_NUMBER
public static final int OUTPUT_BYTES_WRITTEN_FIELD_NUMBER- See Also:
-
OUTPUT_RECORDS_WRITTEN_FIELD_NUMBER
public static final int OUTPUT_RECORDS_WRITTEN_FIELD_NUMBER- See Also:
-
SHUFFLE_REMOTE_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_BLOCKS_FETCHED_FIELD_NUMBER- See Also:
-
SHUFFLE_LOCAL_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_LOCAL_BLOCKS_FETCHED_FIELD_NUMBER- See Also:
-
SHUFFLE_FETCH_WAIT_TIME_FIELD_NUMBER
public static final int SHUFFLE_FETCH_WAIT_TIME_FIELD_NUMBER- See Also:
-
SHUFFLE_REMOTE_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_BYTES_READ_FIELD_NUMBER- See Also:
-
SHUFFLE_REMOTE_BYTES_READ_TO_DISK_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_BYTES_READ_TO_DISK_FIELD_NUMBER- See Also:
-
SHUFFLE_LOCAL_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_LOCAL_BYTES_READ_FIELD_NUMBER- See Also:
-
SHUFFLE_RECORDS_READ_FIELD_NUMBER
public static final int SHUFFLE_RECORDS_READ_FIELD_NUMBER- See Also:
-
SHUFFLE_BYTES_WRITTEN_FIELD_NUMBER
public static final int SHUFFLE_BYTES_WRITTEN_FIELD_NUMBER- See Also:
-
SHUFFLE_WRITE_TIME_FIELD_NUMBER
public static final int SHUFFLE_WRITE_TIME_FIELD_NUMBER- See Also:
-
SHUFFLE_RECORDS_WRITTEN_FIELD_NUMBER
public static final int SHUFFLE_RECORDS_WRITTEN_FIELD_NUMBER- See Also:
-
STAGE_ID_FIELD_NUMBER
public static final int STAGE_ID_FIELD_NUMBER- See Also:
-
STAGE_ATTEMPT_ID_FIELD_NUMBER
public static final int STAGE_ATTEMPT_ID_FIELD_NUMBER- See Also:
-
SHUFFLE_CORRUPT_MERGED_BLOCK_CHUNKS_FIELD_NUMBER
public static final int SHUFFLE_CORRUPT_MERGED_BLOCK_CHUNKS_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_FETCH_FALLBACK_COUNT_FIELD_NUMBER
public static final int SHUFFLE_MERGED_FETCH_FALLBACK_COUNT_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_REMOTE_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_BLOCKS_FETCHED_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_LOCAL_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_LOCAL_BLOCKS_FETCHED_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_REMOTE_CHUNKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_CHUNKS_FETCHED_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_LOCAL_CHUNKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_LOCAL_CHUNKS_FETCHED_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_REMOTE_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_BYTES_READ_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_LOCAL_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_MERGED_LOCAL_BYTES_READ_FIELD_NUMBER- See Also:
-
SHUFFLE_REMOTE_REQS_DURATION_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_REQS_DURATION_FIELD_NUMBER- See Also:
-
SHUFFLE_MERGED_REMOTE_REQ_DURATION_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_REQ_DURATION_FIELD_NUMBER- See Also:
-
-
Method Details
-
getDescriptor
public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() -
getTaskId
public long getTaskId()int64 task_id = 1;
- Specified by:
getTaskId
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The taskId.
-
getIndex
public int getIndex()int32 index = 2;
- Specified by:
getIndex
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The index.
-
getAttempt
public int getAttempt()int32 attempt = 3;
- Specified by:
getAttempt
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The attempt.
-
getPartitionId
public int getPartitionId()int32 partition_id = 4;
- Specified by:
getPartitionId
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The partitionId.
-
getLaunchTime
public long getLaunchTime()int64 launch_time = 5;
- Specified by:
getLaunchTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The launchTime.
-
getResultFetchStart
public long getResultFetchStart()int64 result_fetch_start = 6;
- Specified by:
getResultFetchStart
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The resultFetchStart.
-
getDuration
public long getDuration()int64 duration = 7;
- Specified by:
getDuration
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The duration.
-
hasExecutorId
public boolean hasExecutorId()optional string executor_id = 8;
- Specified by:
hasExecutorId
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- Whether the executorId field is set.
-
getExecutorId
optional string executor_id = 8;
- Specified by:
getExecutorId
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The executorId.
-
getExecutorIdBytes
public com.google.protobuf.ByteString getExecutorIdBytes()optional string executor_id = 8;
- Specified by:
getExecutorIdBytes
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The bytes for executorId.
-
hasHost
public boolean hasHost()optional string host = 9;
- Specified by:
hasHost
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- Whether the host field is set.
-
getHost
optional string host = 9;
- Specified by:
getHost
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The host.
-
getHostBytes
public com.google.protobuf.ByteString getHostBytes()optional string host = 9;
- Specified by:
getHostBytes
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The bytes for host.
-
hasStatus
public boolean hasStatus()optional string status = 10;
- Specified by:
hasStatus
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- Whether the status field is set.
-
getStatus
optional string status = 10;
- Specified by:
getStatus
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The status.
-
getStatusBytes
public com.google.protobuf.ByteString getStatusBytes()optional string status = 10;
- Specified by:
getStatusBytes
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The bytes for status.
-
hasTaskLocality
public boolean hasTaskLocality()optional string task_locality = 11;
- Specified by:
hasTaskLocality
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- Whether the taskLocality field is set.
-
getTaskLocality
optional string task_locality = 11;
- Specified by:
getTaskLocality
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The taskLocality.
-
getTaskLocalityBytes
public com.google.protobuf.ByteString getTaskLocalityBytes()optional string task_locality = 11;
- Specified by:
getTaskLocalityBytes
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The bytes for taskLocality.
-
getSpeculative
public boolean getSpeculative()bool speculative = 12;
- Specified by:
getSpeculative
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The speculative.
-
getAccumulatorUpdatesList
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
- Specified by:
getAccumulatorUpdatesList
in interfaceStoreTypes.TaskDataWrapperOrBuilder
-
getAccumulatorUpdatesOrBuilderList
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
- Specified by:
getAccumulatorUpdatesOrBuilderList
in interfaceStoreTypes.TaskDataWrapperOrBuilder
-
getAccumulatorUpdatesCount
public int getAccumulatorUpdatesCount()repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
- Specified by:
getAccumulatorUpdatesCount
in interfaceStoreTypes.TaskDataWrapperOrBuilder
-
getAccumulatorUpdates
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
- Specified by:
getAccumulatorUpdates
in interfaceStoreTypes.TaskDataWrapperOrBuilder
-
getAccumulatorUpdatesOrBuilder
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
- Specified by:
getAccumulatorUpdatesOrBuilder
in interfaceStoreTypes.TaskDataWrapperOrBuilder
-
hasErrorMessage
public boolean hasErrorMessage()optional string error_message = 14;
- Specified by:
hasErrorMessage
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- Whether the errorMessage field is set.
-
getErrorMessage
optional string error_message = 14;
- Specified by:
getErrorMessage
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The errorMessage.
-
getErrorMessageBytes
public com.google.protobuf.ByteString getErrorMessageBytes()optional string error_message = 14;
- Specified by:
getErrorMessageBytes
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The bytes for errorMessage.
-
getHasMetrics
public boolean getHasMetrics()bool has_metrics = 15;
- Specified by:
getHasMetrics
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The hasMetrics.
-
getExecutorDeserializeTime
public long getExecutorDeserializeTime()int64 executor_deserialize_time = 16;
- Specified by:
getExecutorDeserializeTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The executorDeserializeTime.
-
getExecutorDeserializeCpuTime
public long getExecutorDeserializeCpuTime()int64 executor_deserialize_cpu_time = 17;
- Specified by:
getExecutorDeserializeCpuTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The executorDeserializeCpuTime.
-
getExecutorRunTime
public long getExecutorRunTime()int64 executor_run_time = 18;
- Specified by:
getExecutorRunTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The executorRunTime.
-
getExecutorCpuTime
public long getExecutorCpuTime()int64 executor_cpu_time = 19;
- Specified by:
getExecutorCpuTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The executorCpuTime.
-
getResultSize
public long getResultSize()int64 result_size = 20;
- Specified by:
getResultSize
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The resultSize.
-
getJvmGcTime
public long getJvmGcTime()int64 jvm_gc_time = 21;
- Specified by:
getJvmGcTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The jvmGcTime.
-
getResultSerializationTime
public long getResultSerializationTime()int64 result_serialization_time = 22;
- Specified by:
getResultSerializationTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The resultSerializationTime.
-
getMemoryBytesSpilled
public long getMemoryBytesSpilled()int64 memory_bytes_spilled = 23;
- Specified by:
getMemoryBytesSpilled
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The memoryBytesSpilled.
-
getDiskBytesSpilled
public long getDiskBytesSpilled()int64 disk_bytes_spilled = 24;
- Specified by:
getDiskBytesSpilled
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The diskBytesSpilled.
-
getPeakExecutionMemory
public long getPeakExecutionMemory()int64 peak_execution_memory = 25;
- Specified by:
getPeakExecutionMemory
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The peakExecutionMemory.
-
getInputBytesRead
public long getInputBytesRead()int64 input_bytes_read = 26;
- Specified by:
getInputBytesRead
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The inputBytesRead.
-
getInputRecordsRead
public long getInputRecordsRead()int64 input_records_read = 27;
- Specified by:
getInputRecordsRead
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The inputRecordsRead.
-
getOutputBytesWritten
public long getOutputBytesWritten()int64 output_bytes_written = 28;
- Specified by:
getOutputBytesWritten
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The outputBytesWritten.
-
getOutputRecordsWritten
public long getOutputRecordsWritten()int64 output_records_written = 29;
- Specified by:
getOutputRecordsWritten
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The outputRecordsWritten.
-
getShuffleRemoteBlocksFetched
public long getShuffleRemoteBlocksFetched()int64 shuffle_remote_blocks_fetched = 30;
- Specified by:
getShuffleRemoteBlocksFetched
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleRemoteBlocksFetched.
-
getShuffleLocalBlocksFetched
public long getShuffleLocalBlocksFetched()int64 shuffle_local_blocks_fetched = 31;
- Specified by:
getShuffleLocalBlocksFetched
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleLocalBlocksFetched.
-
getShuffleFetchWaitTime
public long getShuffleFetchWaitTime()int64 shuffle_fetch_wait_time = 32;
- Specified by:
getShuffleFetchWaitTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleFetchWaitTime.
-
getShuffleRemoteBytesRead
public long getShuffleRemoteBytesRead()int64 shuffle_remote_bytes_read = 33;
- Specified by:
getShuffleRemoteBytesRead
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleRemoteBytesRead.
-
getShuffleRemoteBytesReadToDisk
public long getShuffleRemoteBytesReadToDisk()int64 shuffle_remote_bytes_read_to_disk = 34;
- Specified by:
getShuffleRemoteBytesReadToDisk
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleRemoteBytesReadToDisk.
-
getShuffleLocalBytesRead
public long getShuffleLocalBytesRead()int64 shuffle_local_bytes_read = 35;
- Specified by:
getShuffleLocalBytesRead
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleLocalBytesRead.
-
getShuffleRecordsRead
public long getShuffleRecordsRead()int64 shuffle_records_read = 36;
- Specified by:
getShuffleRecordsRead
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleRecordsRead.
-
getShuffleBytesWritten
public long getShuffleBytesWritten()int64 shuffle_bytes_written = 37;
- Specified by:
getShuffleBytesWritten
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleBytesWritten.
-
getShuffleWriteTime
public long getShuffleWriteTime()int64 shuffle_write_time = 38;
- Specified by:
getShuffleWriteTime
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleWriteTime.
-
getShuffleRecordsWritten
public long getShuffleRecordsWritten()int64 shuffle_records_written = 39;
- Specified by:
getShuffleRecordsWritten
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleRecordsWritten.
-
getStageId
public long getStageId()int64 stage_id = 40;
- Specified by:
getStageId
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The stageId.
-
getStageAttemptId
public int getStageAttemptId()int32 stage_attempt_id = 41;
- Specified by:
getStageAttemptId
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The stageAttemptId.
-
getShuffleCorruptMergedBlockChunks
public long getShuffleCorruptMergedBlockChunks()int64 shuffle_corrupt_merged_block_chunks = 42;
- Specified by:
getShuffleCorruptMergedBlockChunks
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleCorruptMergedBlockChunks.
-
getShuffleMergedFetchFallbackCount
public long getShuffleMergedFetchFallbackCount()int64 shuffle_merged_fetch_fallback_count = 43;
- Specified by:
getShuffleMergedFetchFallbackCount
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedFetchFallbackCount.
-
getShuffleMergedRemoteBlocksFetched
public long getShuffleMergedRemoteBlocksFetched()int64 shuffle_merged_remote_blocks_fetched = 44;
- Specified by:
getShuffleMergedRemoteBlocksFetched
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedRemoteBlocksFetched.
-
getShuffleMergedLocalBlocksFetched
public long getShuffleMergedLocalBlocksFetched()int64 shuffle_merged_local_blocks_fetched = 45;
- Specified by:
getShuffleMergedLocalBlocksFetched
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedLocalBlocksFetched.
-
getShuffleMergedRemoteChunksFetched
public long getShuffleMergedRemoteChunksFetched()int64 shuffle_merged_remote_chunks_fetched = 46;
- Specified by:
getShuffleMergedRemoteChunksFetched
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedRemoteChunksFetched.
-
getShuffleMergedLocalChunksFetched
public long getShuffleMergedLocalChunksFetched()int64 shuffle_merged_local_chunks_fetched = 47;
- Specified by:
getShuffleMergedLocalChunksFetched
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedLocalChunksFetched.
-
getShuffleMergedRemoteBytesRead
public long getShuffleMergedRemoteBytesRead()int64 shuffle_merged_remote_bytes_read = 48;
- Specified by:
getShuffleMergedRemoteBytesRead
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedRemoteBytesRead.
-
getShuffleMergedLocalBytesRead
public long getShuffleMergedLocalBytesRead()int64 shuffle_merged_local_bytes_read = 49;
- Specified by:
getShuffleMergedLocalBytesRead
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedLocalBytesRead.
-
getShuffleRemoteReqsDuration
public long getShuffleRemoteReqsDuration()int64 shuffle_remote_reqs_duration = 50;
- Specified by:
getShuffleRemoteReqsDuration
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleRemoteReqsDuration.
-
getShuffleMergedRemoteReqDuration
public long getShuffleMergedRemoteReqDuration()int64 shuffle_merged_remote_req_duration = 51;
- Specified by:
getShuffleMergedRemoteReqDuration
in interfaceStoreTypes.TaskDataWrapperOrBuilder
- Returns:
- The shuffleMergedRemoteReqDuration.
-
isInitialized
public final boolean isInitialized()- Specified by:
isInitialized
in interfacecom.google.protobuf.MessageLiteOrBuilder
- Overrides:
isInitialized
in classcom.google.protobuf.GeneratedMessageV3
-
writeTo
- Specified by:
writeTo
in interfacecom.google.protobuf.MessageLite
- Overrides:
writeTo
in classcom.google.protobuf.GeneratedMessageV3
- Throws:
IOException
-
getSerializedSize
public int getSerializedSize()- Specified by:
getSerializedSize
in interfacecom.google.protobuf.MessageLite
- Overrides:
getSerializedSize
in classcom.google.protobuf.GeneratedMessageV3
-
equals
- Specified by:
equals
in interfacecom.google.protobuf.Message
- Overrides:
equals
in classcom.google.protobuf.AbstractMessage
-
hashCode
public int hashCode()- Specified by:
hashCode
in interfacecom.google.protobuf.Message
- Overrides:
hashCode
in classcom.google.protobuf.AbstractMessage
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(ByteBuffer data) throws com.google.protobuf.InvalidProtocolBufferException - Throws:
com.google.protobuf.InvalidProtocolBufferException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(ByteBuffer data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws com.google.protobuf.InvalidProtocolBufferException - Throws:
com.google.protobuf.InvalidProtocolBufferException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException - Throws:
com.google.protobuf.InvalidProtocolBufferException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.ByteString data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws com.google.protobuf.InvalidProtocolBufferException - Throws:
com.google.protobuf.InvalidProtocolBufferException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(byte[] data) throws com.google.protobuf.InvalidProtocolBufferException - Throws:
com.google.protobuf.InvalidProtocolBufferException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(byte[] data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws com.google.protobuf.InvalidProtocolBufferException - Throws:
com.google.protobuf.InvalidProtocolBufferException
-
parseFrom
- Throws:
IOException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(InputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws IOException - Throws:
IOException
-
parseDelimitedFrom
- Throws:
IOException
-
parseDelimitedFrom
public static StoreTypes.TaskDataWrapper parseDelimitedFrom(InputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws IOException - Throws:
IOException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.CodedInputStream input) throws IOException - Throws:
IOException
-
parseFrom
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws IOException - Throws:
IOException
-
newBuilderForType
- Specified by:
newBuilderForType
in interfacecom.google.protobuf.Message
- Specified by:
newBuilderForType
in interfacecom.google.protobuf.MessageLite
-
newBuilder
-
newBuilder
-
toBuilder
- Specified by:
toBuilder
in interfacecom.google.protobuf.Message
- Specified by:
toBuilder
in interfacecom.google.protobuf.MessageLite
-
getDefaultInstance
-
parser
-
getParserForType
- Specified by:
getParserForType
in interfacecom.google.protobuf.Message
- Specified by:
getParserForType
in interfacecom.google.protobuf.MessageLite
- Overrides:
getParserForType
in classcom.google.protobuf.GeneratedMessageV3
-
getDefaultInstanceForType
- Specified by:
getDefaultInstanceForType
in interfacecom.google.protobuf.MessageLiteOrBuilder
- Specified by:
getDefaultInstanceForType
in interfacecom.google.protobuf.MessageOrBuilder
-