public class ExecutionAttemptID extends Object implements Serializable
Constructor and Description |
---|
ExecutionAttemptID(ExecutionGraphID executionGraphId,
ExecutionVertexID executionVertexId,
int attemptNumber) |
Modifier and Type | Method and Description |
---|---|
boolean |
equals(Object obj) |
static ExecutionAttemptID |
fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf) |
int |
getAttemptNumber() |
static int |
getByteBufLength() |
ExecutionVertexID |
getExecutionVertexId() |
JobVertexID |
getJobVertexId() |
int |
getSubtaskIndex() |
int |
hashCode() |
static ExecutionAttemptID |
randomId() |
String |
toString() |
void |
writeTo(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf) |
public ExecutionAttemptID(ExecutionGraphID executionGraphId, ExecutionVertexID executionVertexId, int attemptNumber)
public ExecutionVertexID getExecutionVertexId()
public JobVertexID getJobVertexId()
public int getSubtaskIndex()
public int getAttemptNumber()
public void writeTo(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf)
public static ExecutionAttemptID fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf)
public static int getByteBufLength()
public static ExecutionAttemptID randomId()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.