Modifier and Type | Method and Description |
---|---|
String |
AbstractRuntimeUDFContext.getAllocationIDAsString() |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<Object>[] |
TupleSerializerBase.getFieldSerializers() |
Modifier and Type | Method and Description |
---|---|
com.esotericsoftware.kryo.Kryo |
KryoSerializer.getKryo() |
Modifier and Type | Method and Description |
---|---|
PatternFlatSelectFunction<IN,OUT1> |
FlatSelectTimeoutCepOperator.FlatSelectWrapper.getFlatSelectFunction() |
PatternFlatTimeoutFunction<IN,OUT2> |
FlatSelectTimeoutCepOperator.FlatSelectWrapper.getFlatTimeoutFunction() |
int |
AbstractKeyedCEPPatternOperator.getPQSize(KEY key) |
boolean |
AbstractKeyedCEPPatternOperator.hasNonEmptyNFA(KEY key) |
boolean |
AbstractKeyedCEPPatternOperator.hasNonEmptyPQ(KEY key) |
Modifier and Type | Method and Description |
---|---|
int |
RocksDBKeyedStateBackend.numStateEntries() |
Modifier and Type | Method and Description |
---|---|
protected OrcRowInputFormat |
OrcTableSource.buildOrcInputFormat() |
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractServerBase.isEventGroupShutdown() |
boolean |
Client.isEventGroupShutdown() |
Modifier and Type | Class and Description |
---|---|
class |
VoidBlobWriter
BlobWriter which does not support writing BLOBs to a store.
|
Modifier and Type | Method and Description |
---|---|
byte[] |
BlobKey.getHash()
Returns the hash component of this key.
|
File |
TransientBlobCache.getStorageLocation(JobID jobId,
BlobKey key)
Returns a file handle to the file associated with the given blob key on the blob
server.
|
File |
BlobServer.getStorageLocation(JobID jobId,
BlobKey key)
Returns a file handle to the file associated with the given blob key on the blob
server.
|
File |
PermanentBlobCache.getStorageLocation(JobID jobId,
BlobKey key)
Returns a file handle to the file associated with the given blob key on the blob
server.
|
Constructor and Description |
---|
PermanentBlobKey()
Constructs a new BLOB key.
|
TransientBlobKey()
Constructs a new BLOB key.
|
Modifier and Type | Method and Description |
---|---|
CheckpointTriggerResult |
CheckpointCoordinator.triggerCheckpoint(long timestamp,
CheckpointProperties props,
String externalSavepointLocation,
boolean isPeriodic) |
Modifier and Type | Method and Description |
---|---|
static KeyedStateHandle |
SavepointV1Serializer.deserializeKeyedStateHandle(DataInputStream dis) |
static OperatorStateHandle |
SavepointV1Serializer.deserializeOperatorStateHandle(DataInputStream dis) |
static StreamStateHandle |
SavepointV1Serializer.deserializeStreamStateHandle(DataInputStream dis) |
static void |
SavepointV1Serializer.serializeKeyedStateHandle(KeyedStateHandle stateHandle,
DataOutputStream dos) |
static void |
SavepointV1Serializer.serializeOperatorStateHandle(OperatorStateHandle stateHandle,
DataOutputStream dos) |
static void |
SavepointV1Serializer.serializeStreamStateHandle(StreamStateHandle stateHandle,
DataOutputStream dos) |
static void |
SavepointSerializers.setFailWhenLegacyStateDetected(boolean fail)
This is only visible as a temporary solution to keep the stateful job migration it cases working from binary
savepoints that still contain legacy state (<= Flink 1.1).
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Collection<TaskManagerLocation>> |
Execution.calculatePreferredLocations(LocationPreferenceConstraint locationPreferenceConstraint)
Calculates the preferred locations based on the location preference constraint.
|
void |
ExecutionVertex.deployToSlot(SimpleSlot slot) |
JobStatus |
ExecutionGraph.waitUntilTerminal() |
Modifier and Type | Method and Description |
---|---|
FailoverRegion |
RestartPipelinedRegionStrategy.getFailoverRegion(ExecutionVertex ev)
Finds the failover region that contains the given execution vertex.
|
Modifier and Type | Method and Description |
---|---|
void |
NetworkEnvironment.setupInputGate(SingleInputGate gate) |
void |
NetworkEnvironment.setupPartition(ResultPartition partition) |
Modifier and Type | Method and Description |
---|---|
int |
ResultSubpartition.getBuffersInBacklog()
Gets the number of non-event buffers in this subpartition.
|
Modifier and Type | Method and Description |
---|---|
void |
RemoteInputChannel.requestSubpartition(int subpartitionIndex)
Requests a remote subpartition.
|
Modifier and Type | Method and Description |
---|---|
Instance |
Scheduler.getInstance(ResourceID resourceId) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.flink.runtime.jobmaster.slotpool.SlotPool.AllocatedSlots |
SlotPool.getAllocatedSlots() |
protected SlotPool.AvailableSlots |
SlotPool.getAvailableSlots() |
Collection<SlotSharingManager.MultiTaskSlot> |
SlotSharingManager.getResolvedRootSlots()
Returns a collection of all resolved root slots.
|
int |
SlotPool.AvailableSlots.size() |
protected void |
SlotPool.timeoutPendingSlotRequest(SlotRequestId slotRequestId) |
Constructor and Description |
---|
SlotPool(RpcService rpcService,
JobID jobId,
SchedulingStrategy schedulingStrategy) |
Constructor and Description |
---|
AcknowledgeCheckpoint(JobID jobId,
ExecutionAttemptID taskExecutionId,
long checkpointId) |
Modifier and Type | Method and Description |
---|---|
akka.actor.ActorRef |
MetricRegistryImpl.getQueryService() |
List<MetricReporter> |
MetricRegistryImpl.getReporters() |
Modifier and Type | Method and Description |
---|---|
int |
KvStateEntry.getCacheSize() |
Modifier and Type | Method and Description |
---|---|
abstract void |
ResourceManager.startNewWorker(ResourceProfile resourceProfile)
Allocates a resource using the resource profile.
|
Modifier and Type | Method and Description |
---|---|
void |
SlotManager.unregisterTaskManagersAndReleaseResources() |
Modifier and Type | Method and Description |
---|---|
void |
MetricStore.add(MetricDump metric) |
Modifier and Type | Method and Description |
---|---|
SecurityConfiguration |
HadoopModule.getSecurityConfig() |
Modifier and Type | Method and Description |
---|---|
SharedStateRegistryKey |
IncrementalKeyedStateHandle.createSharedStateRegistryKeyFromFileName(StateHandleID shId)
Create a unique key to register one of our shared state handles.
|
boolean |
IncrementalKeyedStateHandle.equals(Object o)
This method is should only be called in tests! This should never serve as key in a hash map.
|
StreamCompressionDecorator |
AbstractKeyedStateBackend.getKeyGroupCompressionDecorator() |
int |
IncrementalKeyedStateHandle.hashCode()
This method should only be called in tests! This should never serve as key in a hash map.
|
abstract int |
AbstractKeyedStateBackend.numStateEntries()
Returns the total number of state entries across all keys/namespaces.
|
boolean |
AbstractKeyedStateBackend.supportsAsynchronousSnapshots() |
Constructor and Description |
---|
SharedStateRegistryKey(String keyString) |
StateSnapshotContextSynchronousImpl(long checkpointId,
long checkpointTimestamp) |
Modifier and Type | Method and Description |
---|---|
LocalRecoveryConfig |
HeapKeyedStateBackend.getLocalRecoveryConfig() |
Map<N,Map<K,S>>[] |
NestedMapsStateTable.getState()
Returns the internal data structure.
|
StateTable<K,N,SV> |
AbstractHeapState.getStateTable()
This should only be used for testing.
|
int |
HeapKeyedStateBackend.numStateEntries()
Returns the total number of state entries across all keys/namespaces.
|
int |
HeapKeyedStateBackend.numStateEntries(Object namespace)
Returns the total number of state entries across all keys for the given namespace.
|
abstract int |
StateTable.sizeOfNamespace(Object namespace) |
Modifier and Type | Field and Description |
---|---|
static String |
TaskManagerServices.LOCAL_STATE_SUB_DIRECTORY_ROOT |
Modifier and Type | Method and Description |
---|---|
boolean |
JobLeaderService.containsJob(JobID jobId)
Check whether the service monitors the given job.
|
Modifier and Type | Class and Description |
---|---|
static class |
TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
|
static class |
TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>
Custom
TypeSerializer for the sink state. |
static class |
TwoPhaseCommitSinkFunction.TransactionHolder<TXN>
Adds metadata (currently only the start time of the transaction) to the transaction object.
|
Constructor and Description |
---|
TransactionHolder(TXN handle,
long transactionStartTime) |
Modifier and Type | Method and Description |
---|---|
long |
ContinuousFileMonitoringFunction.getGlobalModificationTime() |
Modifier and Type | Method and Description |
---|---|
Set<InternalTimer<K,N>>[] |
HeapInternalTimerService.getEventTimeTimersPerKeyGroup() |
int |
HeapInternalTimerService.getLocalKeyGroupRangeStartIdx() |
Set<InternalTimer<K,N>>[] |
HeapInternalTimerService.getProcessingTimeTimersPerKeyGroup() |
int |
InternalTimeServiceManager.numEventTimeTimers() |
int |
AbstractStreamOperator.numEventTimeTimers() |
int |
InternalTimeServiceManager.numProcessingTimeTimers() |
int |
AbstractStreamOperator.numProcessingTimeTimers() |
Modifier and Type | Method and Description |
---|---|
long |
TimeEvictor.getWindowSize() |
Modifier and Type | Method and Description |
---|---|
long |
ContinuousEventTimeTrigger.getInterval() |
long |
ContinuousProcessingTimeTrigger.getInterval() |
Trigger<T,W> |
PurgingTrigger.getNestedTrigger() |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.bulk.BulkProcessor |
ElasticsearchSinkBase.buildBulkProcessor(org.elasticsearch.action.bulk.BulkProcessor.Listener listener)
Build the
BulkProcessor . |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink.State<T> |
BucketingSink.getState() |
Modifier and Type | Class and Description |
---|---|
static class |
FlinkKafkaProducer011.ContextStateSerializer
|
static class |
FlinkKafkaProducer011.KafkaTransactionContext
Context associated to this instance of the
FlinkKafkaProducer011 . |
static class |
FlinkKafkaProducer011.TransactionStateSerializer
TypeSerializer for
KafkaTransactionState . |
Modifier and Type | Method and Description |
---|---|
protected <K,V> org.apache.kafka.clients.producer.KafkaProducer<K,V> |
FlinkKafkaProducerBase.getKafkaProducer(Properties props)
Used for testing only.
|
protected long |
FlinkKafkaProducerBase.numPendingRecords() |
Modifier and Type | Method and Description |
---|---|
int |
FlinkKafkaProducer.getTransactionCoordinatorId() |
Modifier and Type | Method and Description |
---|---|
Evictor<? super IN,? super W> |
EvictingWindowOperator.getEvictor() |
KeySelector<IN,K> |
WindowOperator.getKeySelector() |
StateDescriptor<? extends AppendingState<IN,ACC>,?> |
WindowOperator.getStateDescriptor() |
StateDescriptor<? extends AppendingState<IN,Iterable<IN>>,?> |
EvictingWindowOperator.getStateDescriptor() |
Trigger<? super IN,? super W> |
WindowOperator.getTrigger() |
WindowAssigner<? super IN,W> |
WindowOperator.getWindowAssigner() |
Modifier and Type | Class and Description |
---|---|
protected static class |
StatusWatermarkValve.InputChannelStatus
An
InputChannelStatus keeps track of an input channel's last watermark, stream
status, and whether or not the channel's current watermark is aligned with the overall
watermark output from the valve. |
Modifier and Type | Method and Description |
---|---|
protected StatusWatermarkValve.InputChannelStatus |
StatusWatermarkValve.getInputChannelStatus(int channelIndex) |
Modifier and Type | Class and Description |
---|---|
protected static class |
StreamTask.AsyncCheckpointRunnable
This runnable executes the asynchronous parts of all involved backend snapshots for the subtask.
|
Modifier and Type | Method and Description |
---|---|
static <OUT> List<StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>>> |
StreamTask.createStreamRecordWriters(StreamConfig configuration,
Environment environment) |
Constructor and Description |
---|
OneInputStreamTask(Environment env,
ProcessingTimeService timeProvider)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
Modifier and Type | Method and Description |
---|---|
int |
AbstractCloseableRegistry.getNumberOfRegisteredCloseables() |
boolean |
AbstractCloseableRegistry.isCloseableRegistered(Closeable c) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.