Package | Description |
---|---|
org.apache.flink.runtime.state | |
org.apache.flink.streaming.api.operators |
Modifier and Type | Class and Description |
---|---|
class |
KeyGroupRange
This class defines a range of key-group indexes.
|
Modifier and Type | Method and Description |
---|---|
KeyGroupsList |
KeyedStateCheckpointOutputStream.getKeyGroupList()
Returns a list of all key-groups which can be written to this stream.
|
Constructor and Description |
---|
HeapInternalTimerService(int totalKeyGroups,
KeyGroupsList localKeyGroupRange,
KeyContext keyContext,
ProcessingTimeService processingTimeService) |
InternalTimerServiceSerializationProxy(Map<String,HeapInternalTimerService<K,N>> timerServicesMapToPopulate,
ClassLoader userCodeClassLoader,
int totalKeyGroups,
KeyGroupsList localKeyGroupRange,
KeyContext keyContext,
ProcessingTimeService processingTimeService,
int keyGroupIdx)
Constructor to use when restoring timer services.
|
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.