public static final class StoreTypes.TaskDataWrapper extends com.google.protobuf.GeneratedMessageV3 implements StoreTypes.TaskDataWrapperOrBuilder
org.apache.spark.status.protobuf.TaskDataWrapper
Modifier and Type | Class and Description |
---|---|
static class |
StoreTypes.TaskDataWrapper.Builder
Protobuf type
org.apache.spark.status.protobuf.TaskDataWrapper |
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
Modifier and Type | Method and Description |
---|---|
boolean |
equals(Object obj) |
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; |
static StoreTypes.TaskDataWrapper |
getDefaultInstance() |
StoreTypes.TaskDataWrapper |
getDefaultInstanceForType() |
static com.google.protobuf.Descriptors.Descriptor |
getDescriptor() |
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; |
com.google.protobuf.Parser<StoreTypes.TaskDataWrapper> |
getParserForType() |
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; |
int |
getSerializedSize() |
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; |
com.google.protobuf.UnknownFieldSet |
getUnknownFields() |
boolean |
hasErrorMessage()
optional string error_message = 14; |
boolean |
hasExecutorId()
optional string executor_id = 8; |
int |
hashCode() |
boolean |
hasHost()
optional string host = 9; |
boolean |
hasStatus()
optional string status = 10; |
boolean |
hasTaskLocality()
optional string task_locality = 11; |
boolean |
isInitialized() |
static StoreTypes.TaskDataWrapper.Builder |
newBuilder() |
static StoreTypes.TaskDataWrapper.Builder |
newBuilder(StoreTypes.TaskDataWrapper prototype) |
StoreTypes.TaskDataWrapper.Builder |
newBuilderForType() |
static StoreTypes.TaskDataWrapper |
parseDelimitedFrom(java.io.InputStream input) |
static StoreTypes.TaskDataWrapper |
parseDelimitedFrom(java.io.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(java.nio.ByteBuffer data) |
static StoreTypes.TaskDataWrapper |
parseFrom(java.nio.ByteBuffer 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(java.io.InputStream input) |
static StoreTypes.TaskDataWrapper |
parseFrom(java.io.InputStream input,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static com.google.protobuf.Parser<StoreTypes.TaskDataWrapper> |
parser() |
StoreTypes.TaskDataWrapper.Builder |
toBuilder() |
void |
writeTo(com.google.protobuf.CodedOutputStream output) |
getAllFields, getDescriptorForType, getField, getOneofFieldDescriptor, getRepeatedField, getRepeatedFieldCount, hasField, hasOneof
findInitializationErrors, getInitializationErrorString, toString
toByteArray, toByteString, writeDelimitedTo, writeTo
public static final int TASK_ID_FIELD_NUMBER
public static final int INDEX_FIELD_NUMBER
public static final int ATTEMPT_FIELD_NUMBER
public static final int PARTITION_ID_FIELD_NUMBER
public static final int LAUNCH_TIME_FIELD_NUMBER
public static final int RESULT_FETCH_START_FIELD_NUMBER
public static final int DURATION_FIELD_NUMBER
public static final int EXECUTOR_ID_FIELD_NUMBER
public static final int HOST_FIELD_NUMBER
public static final int STATUS_FIELD_NUMBER
public static final int TASK_LOCALITY_FIELD_NUMBER
public static final int SPECULATIVE_FIELD_NUMBER
public static final int ACCUMULATOR_UPDATES_FIELD_NUMBER
public static final int ERROR_MESSAGE_FIELD_NUMBER
public static final int HAS_METRICS_FIELD_NUMBER
public static final int EXECUTOR_DESERIALIZE_TIME_FIELD_NUMBER
public static final int EXECUTOR_DESERIALIZE_CPU_TIME_FIELD_NUMBER
public static final int EXECUTOR_RUN_TIME_FIELD_NUMBER
public static final int EXECUTOR_CPU_TIME_FIELD_NUMBER
public static final int RESULT_SIZE_FIELD_NUMBER
public static final int JVM_GC_TIME_FIELD_NUMBER
public static final int RESULT_SERIALIZATION_TIME_FIELD_NUMBER
public static final int MEMORY_BYTES_SPILLED_FIELD_NUMBER
public static final int DISK_BYTES_SPILLED_FIELD_NUMBER
public static final int PEAK_EXECUTION_MEMORY_FIELD_NUMBER
public static final int INPUT_BYTES_READ_FIELD_NUMBER
public static final int INPUT_RECORDS_READ_FIELD_NUMBER
public static final int OUTPUT_BYTES_WRITTEN_FIELD_NUMBER
public static final int OUTPUT_RECORDS_WRITTEN_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_LOCAL_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_FETCH_WAIT_TIME_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_BYTES_READ_TO_DISK_FIELD_NUMBER
public static final int SHUFFLE_LOCAL_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_RECORDS_READ_FIELD_NUMBER
public static final int SHUFFLE_BYTES_WRITTEN_FIELD_NUMBER
public static final int SHUFFLE_WRITE_TIME_FIELD_NUMBER
public static final int SHUFFLE_RECORDS_WRITTEN_FIELD_NUMBER
public static final int STAGE_ID_FIELD_NUMBER
public static final int STAGE_ATTEMPT_ID_FIELD_NUMBER
public static final int SHUFFLE_CORRUPT_MERGED_BLOCK_CHUNKS_FIELD_NUMBER
public static final int SHUFFLE_MERGED_FETCH_FALLBACK_COUNT_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_LOCAL_BLOCKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_CHUNKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_LOCAL_CHUNKS_FETCHED_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_MERGED_LOCAL_BYTES_READ_FIELD_NUMBER
public static final int SHUFFLE_REMOTE_REQS_DURATION_FIELD_NUMBER
public static final int SHUFFLE_MERGED_REMOTE_REQ_DURATION_FIELD_NUMBER
public final com.google.protobuf.UnknownFieldSet getUnknownFields()
getUnknownFields
in interface com.google.protobuf.MessageOrBuilder
getUnknownFields
in class com.google.protobuf.GeneratedMessageV3
public static final com.google.protobuf.Descriptors.Descriptor getDescriptor()
public long getTaskId()
int64 task_id = 1;
getTaskId
in interface StoreTypes.TaskDataWrapperOrBuilder
public int getIndex()
int32 index = 2;
getIndex
in interface StoreTypes.TaskDataWrapperOrBuilder
public int getAttempt()
int32 attempt = 3;
getAttempt
in interface StoreTypes.TaskDataWrapperOrBuilder
public int getPartitionId()
int32 partition_id = 4;
getPartitionId
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getLaunchTime()
int64 launch_time = 5;
getLaunchTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getResultFetchStart()
int64 result_fetch_start = 6;
getResultFetchStart
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getDuration()
int64 duration = 7;
getDuration
in interface StoreTypes.TaskDataWrapperOrBuilder
public boolean hasExecutorId()
optional string executor_id = 8;
hasExecutorId
in interface StoreTypes.TaskDataWrapperOrBuilder
public String getExecutorId()
optional string executor_id = 8;
getExecutorId
in interface StoreTypes.TaskDataWrapperOrBuilder
public com.google.protobuf.ByteString getExecutorIdBytes()
optional string executor_id = 8;
getExecutorIdBytes
in interface StoreTypes.TaskDataWrapperOrBuilder
public boolean hasHost()
optional string host = 9;
hasHost
in interface StoreTypes.TaskDataWrapperOrBuilder
public String getHost()
optional string host = 9;
getHost
in interface StoreTypes.TaskDataWrapperOrBuilder
public com.google.protobuf.ByteString getHostBytes()
optional string host = 9;
getHostBytes
in interface StoreTypes.TaskDataWrapperOrBuilder
public boolean hasStatus()
optional string status = 10;
hasStatus
in interface StoreTypes.TaskDataWrapperOrBuilder
public String getStatus()
optional string status = 10;
getStatus
in interface StoreTypes.TaskDataWrapperOrBuilder
public com.google.protobuf.ByteString getStatusBytes()
optional string status = 10;
getStatusBytes
in interface StoreTypes.TaskDataWrapperOrBuilder
public boolean hasTaskLocality()
optional string task_locality = 11;
hasTaskLocality
in interface StoreTypes.TaskDataWrapperOrBuilder
public String getTaskLocality()
optional string task_locality = 11;
getTaskLocality
in interface StoreTypes.TaskDataWrapperOrBuilder
public com.google.protobuf.ByteString getTaskLocalityBytes()
optional string task_locality = 11;
getTaskLocalityBytes
in interface StoreTypes.TaskDataWrapperOrBuilder
public boolean getSpeculative()
bool speculative = 12;
getSpeculative
in interface StoreTypes.TaskDataWrapperOrBuilder
public java.util.List<StoreTypes.AccumulableInfo> getAccumulatorUpdatesList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
getAccumulatorUpdatesList
in interface StoreTypes.TaskDataWrapperOrBuilder
public java.util.List<? extends StoreTypes.AccumulableInfoOrBuilder> getAccumulatorUpdatesOrBuilderList()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
getAccumulatorUpdatesOrBuilderList
in interface StoreTypes.TaskDataWrapperOrBuilder
public int getAccumulatorUpdatesCount()
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
getAccumulatorUpdatesCount
in interface StoreTypes.TaskDataWrapperOrBuilder
public StoreTypes.AccumulableInfo getAccumulatorUpdates(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
getAccumulatorUpdates
in interface StoreTypes.TaskDataWrapperOrBuilder
public StoreTypes.AccumulableInfoOrBuilder getAccumulatorUpdatesOrBuilder(int index)
repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
getAccumulatorUpdatesOrBuilder
in interface StoreTypes.TaskDataWrapperOrBuilder
public boolean hasErrorMessage()
optional string error_message = 14;
hasErrorMessage
in interface StoreTypes.TaskDataWrapperOrBuilder
public String getErrorMessage()
optional string error_message = 14;
getErrorMessage
in interface StoreTypes.TaskDataWrapperOrBuilder
public com.google.protobuf.ByteString getErrorMessageBytes()
optional string error_message = 14;
getErrorMessageBytes
in interface StoreTypes.TaskDataWrapperOrBuilder
public boolean getHasMetrics()
bool has_metrics = 15;
getHasMetrics
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getExecutorDeserializeTime()
int64 executor_deserialize_time = 16;
getExecutorDeserializeTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getExecutorDeserializeCpuTime()
int64 executor_deserialize_cpu_time = 17;
getExecutorDeserializeCpuTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getExecutorRunTime()
int64 executor_run_time = 18;
getExecutorRunTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getExecutorCpuTime()
int64 executor_cpu_time = 19;
getExecutorCpuTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getResultSize()
int64 result_size = 20;
getResultSize
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getJvmGcTime()
int64 jvm_gc_time = 21;
getJvmGcTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getResultSerializationTime()
int64 result_serialization_time = 22;
getResultSerializationTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getMemoryBytesSpilled()
int64 memory_bytes_spilled = 23;
getMemoryBytesSpilled
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getDiskBytesSpilled()
int64 disk_bytes_spilled = 24;
getDiskBytesSpilled
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getPeakExecutionMemory()
int64 peak_execution_memory = 25;
getPeakExecutionMemory
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getInputBytesRead()
int64 input_bytes_read = 26;
getInputBytesRead
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getInputRecordsRead()
int64 input_records_read = 27;
getInputRecordsRead
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getOutputBytesWritten()
int64 output_bytes_written = 28;
getOutputBytesWritten
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getOutputRecordsWritten()
int64 output_records_written = 29;
getOutputRecordsWritten
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleRemoteBlocksFetched()
int64 shuffle_remote_blocks_fetched = 30;
getShuffleRemoteBlocksFetched
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleLocalBlocksFetched()
int64 shuffle_local_blocks_fetched = 31;
getShuffleLocalBlocksFetched
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleFetchWaitTime()
int64 shuffle_fetch_wait_time = 32;
getShuffleFetchWaitTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleRemoteBytesRead()
int64 shuffle_remote_bytes_read = 33;
getShuffleRemoteBytesRead
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleRemoteBytesReadToDisk()
int64 shuffle_remote_bytes_read_to_disk = 34;
getShuffleRemoteBytesReadToDisk
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleLocalBytesRead()
int64 shuffle_local_bytes_read = 35;
getShuffleLocalBytesRead
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleRecordsRead()
int64 shuffle_records_read = 36;
getShuffleRecordsRead
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleBytesWritten()
int64 shuffle_bytes_written = 37;
getShuffleBytesWritten
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleWriteTime()
int64 shuffle_write_time = 38;
getShuffleWriteTime
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleRecordsWritten()
int64 shuffle_records_written = 39;
getShuffleRecordsWritten
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getStageId()
int64 stage_id = 40;
getStageId
in interface StoreTypes.TaskDataWrapperOrBuilder
public int getStageAttemptId()
int32 stage_attempt_id = 41;
getStageAttemptId
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleCorruptMergedBlockChunks()
int64 shuffle_corrupt_merged_block_chunks = 42;
getShuffleCorruptMergedBlockChunks
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedFetchFallbackCount()
int64 shuffle_merged_fetch_fallback_count = 43;
getShuffleMergedFetchFallbackCount
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedRemoteBlocksFetched()
int64 shuffle_merged_remote_blocks_fetched = 44;
getShuffleMergedRemoteBlocksFetched
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedLocalBlocksFetched()
int64 shuffle_merged_local_blocks_fetched = 45;
getShuffleMergedLocalBlocksFetched
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedRemoteChunksFetched()
int64 shuffle_merged_remote_chunks_fetched = 46;
getShuffleMergedRemoteChunksFetched
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedLocalChunksFetched()
int64 shuffle_merged_local_chunks_fetched = 47;
getShuffleMergedLocalChunksFetched
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedRemoteBytesRead()
int64 shuffle_merged_remote_bytes_read = 48;
getShuffleMergedRemoteBytesRead
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedLocalBytesRead()
int64 shuffle_merged_local_bytes_read = 49;
getShuffleMergedLocalBytesRead
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleRemoteReqsDuration()
int64 shuffle_remote_reqs_duration = 50;
getShuffleRemoteReqsDuration
in interface StoreTypes.TaskDataWrapperOrBuilder
public long getShuffleMergedRemoteReqDuration()
int64 shuffle_merged_remote_req_duration = 51;
getShuffleMergedRemoteReqDuration
in interface StoreTypes.TaskDataWrapperOrBuilder
public final boolean isInitialized()
isInitialized
in interface com.google.protobuf.MessageLiteOrBuilder
isInitialized
in class com.google.protobuf.GeneratedMessageV3
public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException
writeTo
in interface com.google.protobuf.MessageLite
writeTo
in class com.google.protobuf.GeneratedMessageV3
java.io.IOException
public int getSerializedSize()
getSerializedSize
in interface com.google.protobuf.MessageLite
getSerializedSize
in class com.google.protobuf.GeneratedMessageV3
public boolean equals(Object obj)
equals
in interface com.google.protobuf.Message
equals
in class com.google.protobuf.AbstractMessage
public int hashCode()
hashCode
in interface com.google.protobuf.Message
hashCode
in class com.google.protobuf.AbstractMessage
public static StoreTypes.TaskDataWrapper parseFrom(java.nio.ByteBuffer data) throws com.google.protobuf.InvalidProtocolBufferException
com.google.protobuf.InvalidProtocolBufferException
public static StoreTypes.TaskDataWrapper parseFrom(java.nio.ByteBuffer data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws com.google.protobuf.InvalidProtocolBufferException
com.google.protobuf.InvalidProtocolBufferException
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException
com.google.protobuf.InvalidProtocolBufferException
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.ByteString data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws com.google.protobuf.InvalidProtocolBufferException
com.google.protobuf.InvalidProtocolBufferException
public static StoreTypes.TaskDataWrapper parseFrom(byte[] data) throws com.google.protobuf.InvalidProtocolBufferException
com.google.protobuf.InvalidProtocolBufferException
public static StoreTypes.TaskDataWrapper parseFrom(byte[] data, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws com.google.protobuf.InvalidProtocolBufferException
com.google.protobuf.InvalidProtocolBufferException
public static StoreTypes.TaskDataWrapper parseFrom(java.io.InputStream input) throws java.io.IOException
java.io.IOException
public static StoreTypes.TaskDataWrapper parseFrom(java.io.InputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws java.io.IOException
java.io.IOException
public static StoreTypes.TaskDataWrapper parseDelimitedFrom(java.io.InputStream input) throws java.io.IOException
java.io.IOException
public static StoreTypes.TaskDataWrapper parseDelimitedFrom(java.io.InputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws java.io.IOException
java.io.IOException
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.CodedInputStream input) throws java.io.IOException
java.io.IOException
public static StoreTypes.TaskDataWrapper parseFrom(com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) throws java.io.IOException
java.io.IOException
public StoreTypes.TaskDataWrapper.Builder newBuilderForType()
newBuilderForType
in interface com.google.protobuf.Message
newBuilderForType
in interface com.google.protobuf.MessageLite
public static StoreTypes.TaskDataWrapper.Builder newBuilder()
public static StoreTypes.TaskDataWrapper.Builder newBuilder(StoreTypes.TaskDataWrapper prototype)
public StoreTypes.TaskDataWrapper.Builder toBuilder()
toBuilder
in interface com.google.protobuf.Message
toBuilder
in interface com.google.protobuf.MessageLite
public static StoreTypes.TaskDataWrapper getDefaultInstance()
public static com.google.protobuf.Parser<StoreTypes.TaskDataWrapper> parser()
public com.google.protobuf.Parser<StoreTypes.TaskDataWrapper> getParserForType()
getParserForType
in interface com.google.protobuf.Message
getParserForType
in interface com.google.protobuf.MessageLite
getParserForType
in class com.google.protobuf.GeneratedMessageV3
public StoreTypes.TaskDataWrapper getDefaultInstanceForType()
getDefaultInstanceForType
in interface com.google.protobuf.MessageLiteOrBuilder
getDefaultInstanceForType
in interface com.google.protobuf.MessageOrBuilder