Modifier and Type | Class and Description |
---|---|
class |
JobID
Unique (at least statistically unique) identifier for a Flink Job.
|
Modifier and Type | Method and Description |
---|---|
AbstractID |
BlockingShuffleOutputFormat.getIntermediateDataSetId() |
Modifier and Type | Method and Description |
---|---|
static <T> BlockingShuffleOutputFormat<T> |
BlockingShuffleOutputFormat.createOutputFormat(AbstractID intermediateDataSetId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Set<AbstractID>> |
AbstractSessionClusterExecutor.listCompletedClusterDatasetIds(Configuration configuration,
ClassLoader userCodeClassloader) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
AbstractSessionClusterExecutor.invalidateClusterDataset(AbstractID clusterDatasetId,
Configuration configuration,
ClassLoader userCodeClassloader) |
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<Set<AbstractID>> |
ClusterClient.listCompletedClusterDatasetIds()
Return a set of ids of the completed cluster datasets.
|
CompletableFuture<Set<AbstractID>> |
MiniClusterClient.listCompletedClusterDatasetIds() |
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<Void> |
ClusterClient.invalidateClusterDataset(AbstractID clusterDatasetId)
Invalidate the cached intermediate dataset with the given id.
|
CompletableFuture<Void> |
MiniClusterClient.invalidateClusterDataset(AbstractID clusterDatasetId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Set<AbstractID>> |
RestClusterClient.listCompletedClusterDatasetIds() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
RestClusterClient.invalidateClusterDataset(AbstractID clusterDatasetId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Set<AbstractID>> |
CacheSupportedPipelineExecutor.listCompletedClusterDatasetIds(Configuration configuration,
ClassLoader userCodeClassloader)
Return a set of ids of the completed cluster dataset.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
CacheSupportedPipelineExecutor.invalidateClusterDataset(AbstractID clusterDatasetId,
Configuration configuration,
ClassLoader userCodeClassloader)
Invalidate the cluster dataset with the given id.
|
Modifier and Type | Class and Description |
---|---|
class |
KvStateID
Identifier for state instances.
|
Modifier and Type | Class and Description |
---|---|
class |
AllocationID
Unique identifier for a physical slot allocated by a JobManager via the ResourceManager from a
TaskManager.
|
Modifier and Type | Class and Description |
---|---|
class |
DispatcherId
Fencing token of the
Dispatcher . |
Modifier and Type | Class and Description |
---|---|
class |
ExecutionGraphID
A class for statistically unique execution graph IDs.
|
Modifier and Type | Class and Description |
---|---|
class |
InstanceID
Class for statistically unique instance IDs.
|
class |
SlotSharingGroupId |
Modifier and Type | Class and Description |
---|---|
class |
InputChannelID
Identifier for input channels.
|
Constructor and Description |
---|
InputChannelID(AbstractID id) |
Modifier and Type | Class and Description |
---|---|
class |
IntermediateDataSetID
Id identifying
IntermediateDataSet . |
class |
JobVertexID
A class for statistically unique job vertex IDs.
|
class |
OperatorID
A class for statistically unique operator IDs.
|
Constructor and Description |
---|
IntermediateDataSetID(AbstractID from)
Creates a new intermediate data set ID with the bytes of the given ID.
|
Modifier and Type | Method and Description |
---|---|
AbstractID |
CoLocationGroupImpl.getId() |
AbstractID |
CoLocationGroup.getId()
Returns the unique identifier describing this co-location constraint as a group.
|
Modifier and Type | Class and Description |
---|---|
class |
JobMasterId
The
JobMaster fencing token. |
class |
SlotRequestId
This ID identifies the request for a slot from the Execution to the
SlotPool or PhysicalSlotProvider . |
Modifier and Type | Method and Description |
---|---|
AbstractID |
TaskMetricGroup.vertexId() |
Modifier and Type | Method and Description |
---|---|
JobManagerOperatorMetricGroup |
JobManagerJobMetricGroup.getOrAddOperator(AbstractID vertexId,
String taskName,
OperatorID operatorID,
String operatorName) |
JobManagerOperatorMetricGroup |
UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup.getOrAddOperator(AbstractID vertexId,
String taskName,
OperatorID operatorID,
String operatorName) |
Constructor and Description |
---|
JobManagerOperatorMetricGroup(MetricRegistry registry,
JobManagerJobMetricGroup parent,
AbstractID vertexId,
String taskName,
OperatorID operatorID,
String operatorName) |
Modifier and Type | Method and Description |
---|---|
String[] |
JobManagerOperatorScopeFormat.formatScope(JobManagerJobMetricGroup parent,
AbstractID vertexId,
String taskName,
OperatorID operatorID,
String operatorName) |
String[] |
TaskScopeFormat.formatScope(TaskManagerJobMetricGroup parent,
AbstractID vertexId,
ExecutionAttemptID attemptId,
String taskName,
int subtask,
int attemptNumber) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Set<AbstractID>> |
MiniCluster.listCompletedClusterDatasetIds() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
MiniCluster.invalidateClusterDataset(AbstractID clusterDatasetId) |
Modifier and Type | Class and Description |
---|---|
class |
ResourceManagerId
Fencing token for the
ResourceManager . |
Modifier and Type | Class and Description |
---|---|
class |
PendingTaskManagerId
Id of
PendingTaskManager . |
Modifier and Type | Class and Description |
---|---|
class |
TriggerId
Identifies a savepoint trigger request.
|
Modifier and Type | Method and Description |
---|---|
protected Set<AbstractID> |
StreamExecutionEnvironment.listCompletedClusterDatasets() |
Modifier and Type | Method and Description |
---|---|
void |
StreamExecutionEnvironment.invalidateClusterDataset(AbstractID datasetId) |
<T> void |
StreamExecutionEnvironment.registerCacheTransformation(AbstractID intermediateDataSetID,
CacheTransformation<T> t) |
Modifier and Type | Method and Description |
---|---|
AbstractID |
CacheTransformation.getDatasetId() |
Modifier and Type | Method and Description |
---|---|
int |
AbstractID.compareTo(AbstractID o) |
Constructor and Description |
---|
AbstractID(AbstractID id)
Copy constructor: Creates a new abstract ID from the given one.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.