Modifier and Type | Method and Description |
---|---|
String |
AbstractRuntimeUDFContext.getAllocationIDAsString() |
Constructor and Description |
---|
RuntimeUDFContext(TaskInfo taskInfo,
ClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Future<Path>> cpTasks,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup metrics) |
Modifier and Type | Method and Description |
---|---|
static Set<String> |
FileInputFormat.getSupportedCompressionFormats() |
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 |
---|---|
Collection<State<T>> |
NFA.getStates() |
Modifier and Type | Method and Description |
---|---|
int |
SharedBuffer.getEventsBufferCacheSize() |
int |
SharedBuffer.getEventsBufferSize() |
int |
SharedBuffer.getSharedBufferNodeCacheSize() |
int |
SharedBuffer.getSharedBufferNodeSize() |
Constructor and Description |
---|
SharedBuffer(KeyedStateStore stateStore,
TypeSerializer<V> valueSerializer) |
Modifier and Type | Field and Description |
---|---|
static String |
StateChangeFsUploader.PATH_SUB_DIR |
Modifier and Type | Method and Description |
---|---|
static TaskChangelogRegistry |
TaskChangelogRegistry.defaultChangelogRegistry(Executor executor) |
Path |
StateChangeFsUploader.getBasePath() |
StreamStateHandle |
StateChangeUploader.UploadTasksResult.getStreamStateHandle() |
Constructor and Description |
---|
FsStateChangelogStorage(JobID jobID,
Path basePath,
boolean compression,
int bufferSize,
ChangelogStorageMetricGroup metricGroup,
TaskChangelogRegistry changelogRegistry,
LocalRecoveryConfig localRecoveryConfig) |
FsStateChangelogStorage(StateChangeUploadScheduler uploader,
long preEmptivePersistThresholdInBytes,
TaskChangelogRegistry changelogRegistry,
LocalRecoveryConfig localRecoveryConfig) |
StateChangeFsUploader(JobID jobID,
Path basePath,
FileSystem fileSystem,
boolean compression,
int bufferSize,
ChangelogStorageMetricGroup metrics,
TaskChangelogRegistry changelogRegistry) |
Modifier and Type | Method and Description |
---|---|
List<URL> |
PackagedProgram.Builder.getUserClassPaths() |
Modifier and Type | Method and Description |
---|---|
<M extends MessageHeaders<R,P,U>,U extends MessageParameters,R extends RequestBody,P extends ResponseBody> |
RestClusterClient.sendRequest(M messageHeaders,
U messageParameters,
R request) |
Modifier and Type | Method and Description |
---|---|
static Map<String,String> |
ConfigurationUtils.parseJvmArgString(String jvmParamsStr) |
static Map<String,String> |
ConfigurationUtils.parseTmResourceDynamicConfigs(String dynamicConfigsStr) |
static void |
GlobalConfiguration.setStandardYaml(boolean standardYaml) |
Constructor and Description |
---|
Configuration(boolean standardYaml) |
Modifier and Type | Method and Description |
---|---|
int |
SplitFetcherManager.getNumAliveFetchers() |
Constructor and Description |
---|
SingleThreadFetcherManager(FutureCompletingBlockingQueue<RecordsWithSplitIds<E>> elementsQueue,
Supplier<SplitReader<E,SplitT>> splitReaderSupplier,
Configuration configuration,
Consumer<Collection<String>> splitFinishedHook)
Deprecated.
Please use
SingleThreadFetcherManager(Supplier, Configuration, Consumer)
instead. |
SplitFetcherManager(FutureCompletingBlockingQueue<RecordsWithSplitIds<E>> elementsQueue,
Supplier<SplitReader<E,SplitT>> splitReaderFactory,
Configuration configuration,
Consumer<Collection<String>> splitFinishedHook)
Deprecated.
Please use
SplitFetcherManager(Supplier, Configuration, Consumer)
instead. |
Modifier and Type | Method and Description |
---|---|
T |
FutureCompletingBlockingQueue.take()
Warning: This is a dangerous method and should only be used for testing convenience.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializer<OUT> |
IndexLookupGeneratorFunction.getSerializer() |
TypeSerializer<OUT> |
FromElementsGeneratorFunction.getSerializer() |
Modifier and Type | Method and Description |
---|---|
GeneratorFunction<Long,OUT> |
DataGeneratorSource.getGeneratorFunction() |
Modifier and Type | Method and Description |
---|---|
DataGeneratorSource<RowData> |
DataGenTableSource.createSource() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<?> |
CompactorOperator.getAllTasksFuture() |
Modifier and Type | Method and Description |
---|---|
protected DataStream<RowData> |
HiveTableSource.getDataStream(ProviderContext providerContext,
StreamExecutionEnvironment execEnv) |
PartitionFetcher.Context<P> |
FileSystemLookupFunction.getFetcherContext() |
org.apache.hadoop.mapred.JobConf |
HiveTableSink.getJobConf() |
org.apache.hadoop.mapred.JobConf |
HiveTableSource.getJobConf() |
PartitionFetcher<P> |
FileSystemLookupFunction.getPartitionFetcher() |
PartitionReader<P,RowData> |
FileSystemLookupFunction.getPartitionReader() |
Duration |
FileSystemLookupFunction.getReloadInterval() |
Modifier and Type | Field and Description |
---|---|
protected SplitReader |
HiveTableInputFormat.reader |
Modifier and Type | Method and Description |
---|---|
static long |
RocksDBMemoryControllerUtils.calculateActualCacheCapacity(long totalMemorySize,
double writeBufferRatio)
Calculate the actual memory capacity of cache, which would be shared among rocksDB
instance(s).
|
void |
RocksDBKeyedStateBackend.compactState(StateDescriptor<?,?> stateDesc) |
void |
RocksDBNativeMetricOptions.enableNativeStatistics(ConfigOption<Boolean> nativeStatisticsOption) |
int |
RocksDBPriorityQueueSetFactory.getCacheSize() |
PredefinedOptions |
EmbeddedRocksDBStateBackend.getPredefinedOptions()
Gets the currently set predefined options for RocksDB.
|
PredefinedOptions |
RocksDBStateBackend.getPredefinedOptions()
Deprecated.
Gets the currently set predefined options for RocksDB.
|
int |
RocksDBKeyedStateBackend.numKeyValueStateEntries() |
Constructor and Description |
---|
RocksDBResourceContainer() |
RocksDBResourceContainer(PredefinedOptions predefinedOptions,
RocksDBOptionsFactory optionsFactory) |
RocksDBResourceContainer(PredefinedOptions predefinedOptions,
RocksDBOptionsFactory optionsFactory,
OpaqueMemoryResource<org.apache.flink.contrib.streaming.state.RocksDBSharedResources> sharedResources) |
RocksDBStateDownloader(int restoringThreadNum) |
RocksDBStateUploader(int numberOfSnapshottingThreads) |
Modifier and Type | Method and Description |
---|---|
int |
RefCountedBufferingFileStream.getReferenceCounter() |
Constructor and Description |
---|
RefCountedBufferingFileStream(RefCountedFileWithStream file,
int bufferSize) |
Modifier and Type | Method and Description |
---|---|
static File |
LocalRecoverableWriter.generateStagingTempFilePath(File targetFile) |
Modifier and Type | Method and Description |
---|---|
static MemorySegment |
MemorySegmentFactory.allocateOffHeapUnsafeMemory(int size) |
boolean |
MemorySegment.isFreed()
Checks whether the memory segment was freed.
|
Modifier and Type | Method and Description |
---|---|
static URLClassLoader |
PluginLoader.createPluginClassLoader(PluginDescriptor pluginDescriptor,
ClassLoader parentClassLoader,
String[] alwaysParentFirstPatterns) |
Constructor and Description |
---|
PluginLoader(String pluginId,
URLClassLoader pluginClassLoader) |
Modifier and Type | Method and Description |
---|---|
static List<OptionWithMetaInfo> |
ConfigurationOptionLocator.extractConfigOptions(Class<?> clazz) |
Modifier and Type | Class and Description |
---|---|
static class |
CsvFileFormatFactory.CsvBulkDecodingFormat
CsvBulkDecodingFormat which implements
FileBasedStatisticsReportableInputFormat . |
Modifier and Type | Class and Description |
---|---|
static class |
ParquetFileFormatFactory.ParquetBulkDecodingFormat
ParquetBulkDecodingFormat which implements
FileBasedStatisticsReportableInputFormat . |
Modifier and Type | Method and Description |
---|---|
protected boolean |
ProtoToRowConverter.isCodeSplit() |
boolean |
PbRowDataDeserializationSchema.isCodeSplit() |
Modifier and Type | Method and Description |
---|---|
boolean |
PbRowDataSerializationSchema.isCodeSplit() |
protected boolean |
RowToProtoConverter.isCodeSplit() |
Modifier and Type | Method and Description |
---|---|
io.fabric8.kubernetes.client.NamespacedKubernetesClient |
FlinkKubeClientFactory.createFabric8ioKubernetesClient(Configuration flinkConfig) |
Modifier and Type | Method and Description |
---|---|
static String |
FlinkConfMountDecorator.getFlinkConfConfigMapName(String clusterId) |
Modifier and Type | Field and Description |
---|---|
static String |
KubernetesLeaderElector.LEADER_ANNOTATION_KEY |
Constructor and Description |
---|
KubernetesLeaderElector(io.fabric8.kubernetes.client.NamespacedKubernetesClient kubernetesClient,
KubernetesLeaderElectionConfiguration leaderConfig,
KubernetesLeaderElector.LeaderCallbackHandler leaderCallbackHandler,
ExecutorService executorService) |
Modifier and Type | Class and Description |
---|---|
static class |
OrcFileFormatFactory.OrcBulkDecodingFormat
OrcBulkDecodingFormat which implements
FileBasedStatisticsReportableInputFormat . |
Modifier and Type | Method and Description |
---|---|
org.apache.orc.RecordReader |
OrcSplitReader.getRecordReader() |
Modifier and Type | Method and Description |
---|---|
protected org.apache.orc.OrcFile.WriterOptions |
OrcBulkWriterFactory.getWriterOptions() |
Modifier and Type | Field and Description |
---|---|
static String |
AbstractPythonEnvironmentManager.PYFLINK_GATEWAY_DISABLED |
static String |
AbstractPythonEnvironmentManager.PYTHON_ARCHIVES_DIR |
static String |
AbstractPythonEnvironmentManager.PYTHON_FILES_DIR |
static String |
AbstractPythonEnvironmentManager.PYTHON_REQUIREMENTS_CACHE |
static String |
AbstractPythonEnvironmentManager.PYTHON_REQUIREMENTS_DIR |
static String |
AbstractPythonEnvironmentManager.PYTHON_REQUIREMENTS_FILE |
static String |
AbstractPythonEnvironmentManager.PYTHON_REQUIREMENTS_INSTALL_DIR |
static String |
AbstractPythonEnvironmentManager.PYTHON_WORKING_DIR |
Modifier and Type | Method and Description |
---|---|
Map<String,String> |
AbstractPythonEnvironmentManager.constructEnvironmentVariables(String baseDirectory)
Constructs the environment variables which is used to launch the python UDF worker.
|
String |
AbstractPythonEnvironmentManager.getBaseDirectory() |
Map<String,String> |
AbstractPythonEnvironmentManager.getPythonEnv() |
Modifier and Type | Field and Description |
---|---|
static String |
PythonEnvironmentManagerUtils.PYFLINK_UDF_RUNNER_DIR |
Modifier and Type | Method and Description |
---|---|
boolean |
Client.isEventGroupShutdown() |
boolean |
AbstractServerBase.isEventGroupShutdown() |
Modifier and Type | Method and Description |
---|---|
int |
AsyncExecutionController.getInFlightRecordNum() |
StateExecutor |
AsyncExecutionController.getStateExecutor() |
int |
KeyAccountingUnit.occupiedCount() |
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 |
PermanentBlobCache.getStorageLocation(JobID jobId,
BlobKey key)
Returns a file handle to the file associated with the given blob key on the blob server.
|
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.
|
Constructor and Description |
---|
BlobServer(Configuration config,
File storageDir,
BlobStore blobStore) |
PermanentBlobCache(Configuration blobClientConfig,
File storageDir,
BlobView blobView,
InetSocketAddress serverAddress) |
PermanentBlobCache(Configuration blobClientConfig,
File storageDir,
BlobView blobView,
InetSocketAddress serverAddress,
BlobCacheSizeTracker blobCacheSizeTracker) |
PermanentBlobCache(Configuration blobClientConfig,
Reference<File> storageDir,
BlobView blobView,
InetSocketAddress serverAddress,
BlobCacheSizeTracker blobCacheSizeTracker) |
PermanentBlobKey()
Constructs a new BLOB key.
|
TransientBlobCache(Configuration blobClientConfig,
File storageDir,
InetSocketAddress serverAddress) |
TransientBlobKey()
Constructs a new BLOB key.
|
Modifier and Type | Method and Description |
---|---|
SubTaskInitializationMetrics |
SubTaskInitializationMetricsBuilder.build(long endTs) |
static void |
StateAssignmentOperation.extractIntersectingState(Collection<? extends KeyedStateHandle> originalSubtaskStateHandles,
KeyGroupRange rangeToExtract,
List<KeyedStateHandle> extractedStateCollector)
Extracts certain key group ranges from the given state handles and adds them to the
collector.
|
static CheckpointOptions |
CheckpointOptions.forCheckpointWithDefaultLocation() |
Collection<ExecutionJobVertex> |
CheckpointPlan.getFullyFinishedJobVertex()
Returns the job vertices whose tasks are all finished when taking the checkpoint.
|
ArrayDeque<Long> |
CheckpointCoordinator.getRecentExpiredCheckpoints() |
static <T extends CompletedCheckpointStore> |
PerJobCheckpointRecoveryFactory.withoutCheckpointStoreRecovery(IntFunction<T> storeFn) |
Modifier and Type | Method and Description |
---|---|
ChannelStateWriter.ChannelStateWriteResult |
ChannelStateWriterImpl.getWriteResult(long checkpointId) |
void |
ChannelStateWriter.ChannelStateWriteResult.waitForDone() |
Modifier and Type | Field and Description |
---|---|
static String |
FileMergingMetricGroup.LOGICAL_FILE_COUNT |
static String |
FileMergingMetricGroup.LOGICAL_FILE_SIZE |
static String |
FileMergingMetricGroup.PHYSICAL_FILE_COUNT |
static String |
FileMergingMetricGroup.PHYSICAL_FILE_SIZE |
Modifier and Type | Method and Description |
---|---|
String |
FileMergingSnapshotManagerBase.getId() |
String |
FileMergingSnapshotManager.SubtaskKey.getJobIDString() |
LogicalFile |
FileMergingSnapshotManagerBase.getLogicalFile(LogicalFile.LogicalFileId fileId) |
boolean |
LogicalFile.isDiscarded() |
Constructor and Description |
---|
SubtaskKey(String jobIDString,
String operatorIDString,
int subtaskIndex,
int parallelism) |
Constructor and Description |
---|
TaskExecutorProcessSpec(CPUResource cpuCores,
MemorySize frameworkHeapSize,
MemorySize frameworkOffHeapSize,
MemorySize taskHeapSize,
MemorySize taskOffHeapSize,
MemorySize networkMemSize,
MemorySize managedMemorySize,
MemorySize jvmMetaspaceSize,
MemorySize jvmOverheadSize,
Collection<ExternalResource> extendedResources) |
Modifier and Type | Field and Description |
---|---|
static ResourceProfile |
ResourceProfile.ANY
A ResourceProfile that indicates infinite resource that matches any resource requirement.
|
Modifier and Type | Method and Description |
---|---|
static ResourceProfile |
ResourceProfile.fromResources(double cpuCores,
int taskHeapMemoryMB) |
Constructor and Description |
---|
InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId,
ResultPartitionType consumedPartitionType,
int consumedSubpartitionIndex,
TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[] inputChannels) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Duration> |
Dispatcher.CLIENT_ALIVENESS_CHECK_DURATION |
Modifier and Type | Method and Description |
---|---|
protected CompletableFuture<org.apache.flink.runtime.dispatcher.Dispatcher.CleanupJobState> |
Dispatcher.jobReachedTerminalState(ExecutionGraphInfo executionGraphInfo) |
Constructor and Description |
---|
Dispatcher(RpcService rpcService,
DispatcherId fencingToken,
Collection<JobGraph> recoveredJobs,
Collection<JobResult> recoveredDirtyJobs,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
DispatcherServices dispatcherServices,
JobManagerRunnerRegistry jobManagerRunnerRegistry,
ResourceCleanerFactory resourceCleanerFactory) |
DispatcherOperationCaches() |
DispatcherOperationCaches(Duration cacheDuration) |
MiniDispatcher(RpcService rpcService,
DispatcherId fencingToken,
DispatcherServices dispatcherServices,
JobGraph jobGraph,
JobResult recoveredDirtyJob,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
JobManagerRunnerRegistry jobManagerRunnerRegistry,
ResourceCleanerFactory resourceCleanerFactory,
ClusterEntrypoint.ExecutionMode executionMode) |
Constructor and Description |
---|
DispatcherResourceCleanerFactory(Executor cleanupExecutor,
RetryStrategy retryStrategy,
JobManagerRunnerRegistry jobManagerRunnerRegistry,
JobGraphWriter jobGraphWriter,
BlobServer blobServer,
HighAvailabilityServices highAvailabilityServices,
JobManagerMetricGroup jobManagerMetricGroup) |
Modifier and Type | Method and Description |
---|---|
static File |
ClusterEntrypointUtils.generateJobManagerWorkingDirectoryFile(Configuration configuration,
ResourceID resourceId)
Generates the working directory
File for the JobManager process. |
static File |
ClusterEntrypointUtils.generateTaskManagerWorkingDirectoryFile(Configuration configuration,
ResourceID resourceId)
Generates the working directory
File for the TaskManager process. |
Modifier and Type | Method and Description |
---|---|
ResultPartitionID |
DefaultExecutionGraph.createResultPartitionId(IntermediateResultPartitionID resultPartitionId) |
void |
ExecutionVertex.deployToSlot(LogicalSlot slot) |
List<IntermediateResultPartition> |
ExecutionVertex.finishPartitionsIfNeeded()
Mark partition finished if needed.
|
void |
Execution.markFinished() |
JobStatus |
DefaultExecutionGraph.waitUntilTerminal() |
JobStatus |
ExecutionGraph.waitUntilTerminal() |
Constructor and Description |
---|
ArchivedExecutionVertex(int subTaskIndex,
String taskNameWithSubtask,
ArchivedExecution currentExecution,
ExecutionHistory executionHistory) |
ExecutionJobVertex(InternalExecutionGraphAccessor graph,
JobVertex jobVertex,
VertexParallelismInformation parallelismInfo,
CoordinatorStore coordinatorStore,
JobManagerJobMetricGroup jobManagerJobMetricGroup) |
ExecutionVertex(ExecutionJobVertex jobVertex,
int subTaskIndex,
IntermediateResult[] producedDataSets,
Time timeout,
long createTimestamp,
int executionHistorySizeLimit,
int initialAttemptCount)
Creates an ExecutionVertex.
|
IOMetrics(long numBytesIn,
long numBytesOut,
long numRecordsIn,
long numRecordsOut,
long accumulateIdleTime,
double accumulateBusyTime,
long accumulateBackPressuredTime,
Map<IntermediateResultPartitionID,ResultPartitionBytes> resultPartitionBytes) |
Modifier and Type | Method and Description |
---|---|
SchedulingPipelinedRegion |
RestartPipelinedRegionFailoverStrategy.getFailoverRegion(ExecutionVertexID vertexID)
Returns the failover region that contains the given execution vertex.
|
Constructor and Description |
---|
RestartPipelinedRegionFailoverStrategy(SchedulingTopology topology)
Creates a new failover strategy to restart pipelined regions that works on the given
topology.
|
Modifier and Type | Method and Description |
---|---|
boolean |
RegionPartitionGroupReleaseStrategy.isRegionOfVertexFinished(ExecutionVertexID executionVertexId) |
Modifier and Type | Method and Description |
---|---|
static boolean |
FileSystemJobResultStore.hasValidDirtyJobResultStoreEntryExtension(String filename) |
static boolean |
FileSystemJobResultStore.hasValidJobResultStoreEntryExtension(String filename) |
Modifier and Type | Method and Description |
---|---|
boolean |
EmbeddedLeaderService.isShutdown() |
Modifier and Type | Method and Description |
---|---|
int |
BatchShuffleReadBufferPool.getAvailableBuffers() |
int |
BatchShuffleReadBufferPool.getNumTotalBuffers() |
Constructor and Description |
---|
IOManagerAsync()
Constructs a new asynchronous I/O manager, writing files to the system 's temp directory.
|
IOManagerAsync(ExecutorService executorService)
Constructs a new asynchronous I/O manager, writing files to the system 's temp directory.
|
IOManagerAsync(String tempDir)
Constructs a new asynchronous I/O manager, writing file to the given directory.
|
IOManagerAsync(String tempDir,
ExecutorService executorService)
Constructs a new asynchronous I/O manager, writing file to the given directory.
|
Modifier and Type | Field and Description |
---|---|
static String |
RecordWriter.DEFAULT_OUTPUT_FLUSH_THREAD_NAME
Default name for the output flush thread, if no name with a task reference is given.
|
Modifier and Type | Method and Description |
---|---|
ChannelSelector<T> |
ChannelSelectorRecordWriter.getChannelSelector() |
static ByteBuffer |
RecordWriter.serializeRecord(DataOutputSerializer serializer,
IOReadableWritable record) |
Modifier and Type | Method and Description |
---|---|
Buffer |
BufferDecompressor.decompressToOriginalBuffer(Buffer buffer)
The difference between this method and
BufferDecompressor.decompressToIntermediateBuffer(Buffer) is
that this method copies the decompressed data to the input Buffer starting from
offset 0. |
int |
LocalBufferPool.getNumberOfRequestedMemorySegments() |
Constructor and Description |
---|
NetworkBufferPool(int numberOfSegmentsToAllocate,
int segmentSize) |
Modifier and Type | Method and Description |
---|---|
abstract int |
AbstractBuffersUsageGauge.calculateTotalBuffers(SingleInputGate inputGate) |
abstract int |
AbstractBuffersUsageGauge.calculateUsedBuffers(SingleInputGate inputGate) |
Constructor and Description |
---|
NettyConnectionManager(NettyBufferPool bufferPool,
ResultPartitionProvider partitionProvider,
TaskEventPublisher taskEventPublisher,
NettyConfig nettyConfig,
int maxNumberOfConnections,
boolean connectionReuseEnabled) |
NettyPartitionRequestListener(ResultPartitionProvider resultPartitionProvider,
NetworkSequenceViewReader reader,
ResultSubpartitionIndexSet subpartitionIndexSet,
ResultPartitionID resultPartitionId,
long createTimestamp) |
Modifier and Type | Method and Description |
---|---|
int |
ResultSubpartition.add(BufferConsumer bufferConsumer) |
ResultPartition |
ResultPartitionFactory.create(String taskNameWithSubtaskAndId,
int partitionIndex,
ResultPartitionID id,
ResultPartitionType type,
int numberOfPartitions,
int numberOfSubpartitions,
int maxParallelism,
boolean isBroadcast,
ShuffleDescriptor shuffleDescriptor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
boolean isNumberOfPartitionConsumerUndefined) |
ResultSubpartition[] |
BufferWritingResultPartition.getAllPartitions() |
long |
PipelinedSubpartition.getChannelStateCheckpointId() |
TimerGauge |
BufferWritingResultPartition.getHardBackPressuredTimeMsPerSecond() |
Map<ResultPartitionID,PartitionRequestListenerManager> |
ResultPartitionManager.getListenerManagers() |
ResultPartitionManager |
ResultPartition.getPartitionManager() |
static DataSetMetaInfo |
DataSetMetaInfo.withNumRegisteredPartitions(int numRegisteredPartitions,
int numTotalPartitions) |
Constructor and Description |
---|
ResultPartitionID() |
ResultPartitionManager() |
Modifier and Type | Method and Description |
---|---|
void |
SingleInputGate.announceBufferSize(int newBufferSize) |
void |
SingleInputGate.convertRecoveredInputChannels() |
protected InputChannel |
SingleInputGateFactory.createKnownInputChannel(SingleInputGate inputGate,
int index,
int buffersPerChannel,
NettyShuffleDescriptor inputChannelDescriptor,
ResultSubpartitionIndexSet subpartitionIndexSet,
SingleInputGateFactory.ChannelStatistics channelStatistics,
InputChannelMetrics metrics) |
Map<Tuple2<IntermediateResultPartitionID,InputChannelInfo>,InputChannel> |
SingleInputGate.getInputChannels() |
Buffer |
RemoteInputChannel.getNextReceivedBuffer() |
int |
RemoteInputChannel.getNumberOfAvailableBuffers() |
protected int |
RecoveredInputChannel.getNumberOfQueuedBuffers() |
int |
RemoteInputChannel.getNumberOfRequiredBuffers() |
int |
RemoteInputChannel.getSenderBacklog() |
void |
RemoteInputChannel.requestSubpartitions()
Requests a remote subpartition.
|
void |
SingleInputGate.setupChannels()
Assign the exclusive buffers to all remote input channels directly for credit-based mode.
|
Constructor and Description |
---|
BufferOrEvent(AbstractEvent event,
InputChannelInfo channelInfo) |
BufferOrEvent(Buffer buffer,
InputChannelInfo channelInfo) |
Constructor and Description |
---|
IntermediateResultPartitionID()
Creates an new random intermediate result partition ID for testing.
|
Constructor and Description |
---|
CheckpointCoordinatorConfiguration(long checkpointInterval,
long checkpointTimeout,
long minPauseBetweenCheckpoints,
int maxConcurrentCheckpoints,
CheckpointRetentionPolicy checkpointRetentionPolicy,
boolean isExactlyOnce,
boolean isUnalignedCheckpoint,
int tolerableCpFailureNumber,
long checkpointIdOfIgnoredInFlightData)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static JobManagerProcessSpec |
JobManagerProcessUtils.createDefaultJobManagerProcessSpec(int totalProcessMemoryMb) |
Constructor and Description |
---|
JobManagerProcessSpec(MemorySize jvmHeapSize,
MemorySize offHeapSize,
MemorySize jvmMetaspaceSize,
MemorySize jvmOverheadSize) |
Modifier and Type | Method and Description |
---|---|
protected void |
FileSystemJobEventStore.writeEventRunnable(JobEvent event,
boolean cutBlock) |
Constructor and Description |
---|
FileSystemJobEventStore(Path workingDir,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
int |
DeclarativeSlotPoolBridge.getNumPendingRequests() |
Constructor and Description |
---|
SingleLogicalSlot(SlotRequestId slotRequestId,
SlotContext slotContext,
Locality locality,
SlotOwner slotOwner) |
Modifier and Type | Method and Description |
---|---|
UUID |
DefaultLeaderElectionService.getLeaderSessionID(String componentId)
Returns the current leader session ID for the given
componentId or null , if
the session wasn't confirmed. |
Constructor and Description |
---|
DefaultLeaderElectionService(LeaderElectionDriverFactory leaderElectionDriverFactory,
FatalErrorHandler fallbackErrorHandler) |
Modifier and Type | Method and Description |
---|---|
String |
ZooKeeperLeaderRetrievalDriver.getConnectionInformationPath() |
Modifier and Type | Method and Description |
---|---|
boolean |
MemoryManager.isShutdown()
Checks whether the MemoryManager has been shut down.
|
Constructor and Description |
---|
AcknowledgeCheckpoint(JobID jobId,
ExecutionAttemptID taskExecutionId,
long checkpointId) |
Constructor and Description |
---|
JobDetails(JobID jobId,
String jobName,
long startTime,
long endTime,
long duration,
JobStatus status,
long lastUpdateTime,
int[] tasksPerState,
int numTasks) |
Modifier and Type | Method and Description |
---|---|
static ReporterSetup |
ReporterSetup.forReporter(String reporterName,
MetricConfig metricConfig,
MetricReporter reporter) |
static TraceReporterSetup |
TraceReporterSetup.forReporter(String reporterName,
MetricConfig metricConfig,
TraceReporter reporter) |
static ReporterSetup |
ReporterSetup.forReporter(String reporterName,
MetricFilter metricFilter,
MetricReporter reporter) |
static ReporterSetup |
ReporterSetup.forReporter(String reporterName,
MetricReporter reporter) |
static TraceReporterSetup |
TraceReporterSetup.forReporter(String reporterName,
TraceReporter reporter) |
long |
TimerGauge.getCount() |
List<MetricReporter> |
MetricRegistryImpl.getReporters() |
boolean |
TimerGauge.isMeasuring() |
Constructor and Description |
---|
ThresholdMeter(double maxEventsPerInterval,
Duration interval,
Clock clock) |
Modifier and Type | Method and Description |
---|---|
TaskManagerJobMetricGroup |
TaskManagerMetricGroup.getJobMetricsGroup(JobID jobId) |
long |
TaskIOMetricGroup.getTaskInitializationDuration()
Returns the duration of time required for a task's restoring/initialization, which reaches
its maximum when the task begins running and remains constant throughout the task's running.
|
static InternalSourceReaderMetricGroup |
InternalSourceReaderMetricGroup.mock(MetricGroup metricGroup) |
Modifier and Type | Method and Description |
---|---|
protected Collection<? extends DispatcherResourceManagerComponent> |
MiniCluster.createDispatcherResourceManagerComponents(Configuration configuration,
MiniCluster.RpcServiceFactory rpcServiceFactory,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
MetricRegistry metricRegistry,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
protected HighAvailabilityServices |
MiniCluster.createHighAvailabilityServices(Configuration configuration,
Executor executor) |
Configuration |
MiniCluster.getConfiguration() |
protected CompletableFuture<DispatcherGateway> |
MiniCluster.getDispatcherGatewayFuture() |
protected boolean |
MiniCluster.useLocalCommunication() |
Modifier and Type | Method and Description |
---|---|
static SSLContext |
SSLUtils.createRestSSLContext(Configuration config,
boolean clientMode)
Creates an SSL context for clients against the external REST endpoint.
|
Modifier and Type | Method and Description |
---|---|
protected OperatorCoordinator |
RecreateOnResetOperatorCoordinator.Provider.create(OperatorCoordinator.Context context,
long closingTimeoutMs) |
Constructor and Description |
---|
PossibleInconsistentStateException() |
Modifier and Type | Method and Description |
---|---|
int |
KvStateEntry.getCacheSize() |
Modifier and Type | Method and Description |
---|---|
static Configuration |
StandaloneResourceManagerFactory.getConfigurationWithoutResourceLimitationIfSet(Configuration configuration)
Get the configuration for standalone ResourceManager, overwrite invalid configs.
|
Optional<InstanceID> |
ResourceManager.getInstanceIdByResourceId(ResourceID resourceID) |
ResourceManager<?> |
ResourceManagerServiceImpl.getLeaderResourceManager() |
Modifier and Type | Method and Description |
---|---|
void |
ActiveResourceManager.declareResourceNeeded(Collection<ResourceDeclaration> resourceDeclarations) |
void |
ActiveResourceManager.requestNewWorker(WorkerResourceSpec workerResourceSpec)
Allocates a resource using the worker resource specification.
|
Modifier and Type | Method and Description |
---|---|
long |
FineGrainedSlotManager.getTaskManagerIdleSince(InstanceID instanceId) |
Modifier and Type | Method and Description |
---|---|
static <R extends RequestBody,M extends MessageParameters> |
HandlerRequest.create(R requestBody,
M messageParameters)
Short-cut for
HandlerRequest.create(RequestBody, MessageParameters, Collection) without any
uploaded files. |
static <R extends RequestBody,M extends MessageParameters> |
HandlerRequest.create(R requestBody,
M messageParameters,
Collection<File> uploadedFiles)
Creates a new
HandlerRequest . |
Modifier and Type | Method and Description |
---|---|
void |
MetricStore.add(MetricDump metric) |
Modifier and Type | Method and Description |
---|---|
protected static String |
ThreadDumpInfo.stringifyThreadInfo(ThreadInfo threadInfo,
int maxDepth)
Custom stringify format of JVM thread info to bypass the MAX_FRAMES = 8 limitation.
|
Modifier and Type | Method and Description |
---|---|
TaskManagerMetricsInfo |
TaskManagerDetailsInfo.getTaskManagerMetricsInfo() |
Modifier and Type | Method and Description |
---|---|
static void |
RpcUtils.terminateRpcEndpoint(RpcEndpoint... rpcEndpoints)
Shuts the given
RpcEndpoint s down and awaits their termination. |
static void |
RpcUtils.terminateRpcService(RpcService... rpcServices)
Shuts the given rpc services down and waits for their termination.
|
Modifier and Type | Method and Description |
---|---|
static org.apache.pekko.actor.ActorSystem |
ActorSystemBootstrapTools.startRemoteActorSystem(Configuration configuration,
String externalAddress,
String externalPortRange,
org.slf4j.Logger logger)
Starts a remote ActorSystem at given address and specific port range.
|
Constructor and Description |
---|
PekkoRpcService(org.apache.pekko.actor.ActorSystem actorSystem,
PekkoRpcServiceConfiguration configuration) |
Modifier and Type | Method and Description |
---|---|
Iterable<RootExceptionHistoryEntry> |
SchedulerBase.getExceptionHistory() |
ExecutionGraph |
SchedulerBase.getExecutionGraph()
ExecutionGraph is exposed to make it easier to rework tests to be based on the new scheduler.
|
protected JobID |
SchedulerBase.getJobId() |
Modifier and Type | Method and Description |
---|---|
static VertexParallelismStore |
AdaptiveBatchScheduler.computeVertexParallelismStoreForDynamicGraph(Iterable<JobVertex> vertices,
int defaultMaxParallelism)
Compute the
VertexParallelismStore for all given vertices in a dynamic graph, which
will set defaults and ensure that the returned store contains valid parallelisms, with the
configured default max parallelism. |
static AdaptiveBatchScheduler |
AdaptiveBatchSchedulerFactory.createScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
ExecutionConfig executionConfig,
Executor ioExecutor,
Configuration jobMasterConfiguration,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
Collection<FailureEnricher> failureEnrichers,
BlocklistOperations blocklistOperations,
ExecutionOperations executionOperations,
ExecutionSlotAllocatorFactory allocatorFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
ScheduledExecutor delayExecutor,
VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider,
BatchJobRecoveryHandler jobRecoveryHandler) |
void |
AdaptiveBatchScheduler.initializeVerticesIfPossible() |
Constructor and Description |
---|
RootExceptionHistoryEntry(Throwable cause,
long timestamp,
CompletableFuture<Map<String,String>> failureLabels,
String failingTaskName,
TaskManagerLocation taskManagerLocation,
Collection<ExceptionHistoryEntry> concurrentExceptions)
Instantiates a
RootExceptionHistoryEntry . |
Modifier and Type | Method and Description |
---|---|
static String |
StateTimeMetric.getCurrentTimeMetricName(String baseName) |
static String |
StateTimeMetric.getStateMetricName(String baseName) |
static String |
StateTimeMetric.getTotalTimeMetricName(String baseName) |
Modifier and Type | Method and Description |
---|---|
SecurityConfiguration |
HadoopModule.getSecurityConfig() |
Constructor and Description |
---|
NetworkPartitionConnectionInfo(InetSocketAddress address,
int connectionIndex) |
PartitionDescriptor(IntermediateDataSetID resultId,
int totalNumberOfPartitions,
IntermediateResultPartitionID partitionId,
ResultPartitionType partitionType,
int numberOfSubpartitions,
int connectionIndex,
boolean isBroadcast,
boolean isAllToAllDistribution,
boolean isNumberOfPartitionConsumerUndefined) |
ProducerDescriptor(ResourceID producerLocation,
ExecutionAttemptID producerExecutionId,
InetAddress address,
int dataPort) |
Modifier and Type | Method and Description |
---|---|
ExecutorService |
SourceCoordinator.getCoordinatorExecutor() |
SplitEnumerator<SplitT,EnumChkT> |
SourceCoordinator.getEnumerator() |
Modifier and Type | Class and Description |
---|---|
class |
JavaSerializer<T extends Serializable>
A
TypeSerializer that uses Java serialization. |
interface |
TestableKeyedStateBackend<K>
A keyed state backend interface for internal testing purpose.
|
Modifier and Type | Field and Description |
---|---|
protected boolean |
DefaultOperatorStateBackendBuilder.asynchronousSnapshots
Flag to de/activate asynchronous snapshots.
|
protected CloseableRegistry |
DefaultOperatorStateBackendBuilder.cancelStreamRegistry |
protected ExecutionConfig |
DefaultOperatorStateBackendBuilder.executionConfig
The execution configuration.
|
protected Collection<OperatorStateHandle> |
DefaultOperatorStateBackendBuilder.restoreStateHandles
State handles for restore.
|
protected ClassLoader |
DefaultOperatorStateBackendBuilder.userClassloader
The user code classloader.
|
Modifier and Type | Method and Description |
---|---|
protected void |
AsyncSnapshotCallable.cancel() |
Optional<StateChangelogStorage<?>> |
TaskExecutorStateChangelogStoragesManager.getChangelogStoragesByJobId(JobID jobId) |
ChannelStateWriteRequestExecutorFactory |
TaskExecutorChannelStateExecutorFactoryManager.getFactoryByJobId(JobID jobId) |
ArrayListSerializer<S> |
PartitionableListState.getInternalListCopySerializer() |
MapSerializer<K,V> |
HeapBroadcastState.getInternalMapCopySerializer() |
StreamCompressionDecorator |
AbstractKeyedStateBackend.getKeyGroupCompressionDecorator() |
int |
AbstractKeyedStateBackend.numKeyValueStatesByName() |
Constructor and Description |
---|
IncrementalRemoteKeyedStateHandle(UUID backendIdentifier,
KeyGroupRange keyGroupRange,
long checkpointId,
List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState,
List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState,
StreamStateHandle metaStateHandle) |
InputChannelStateHandle(InputChannelInfo info,
StreamStateHandle delegate,
List<Long> offset) |
ResultSubpartitionStateHandle(ResultSubpartitionInfo info,
StreamStateHandle delegate,
List<Long> offset) |
SharedStateRegistryKey(String keyString) |
StateSnapshotContextSynchronousImpl(long checkpointId,
long checkpointTimestamp) |
Modifier and Type | Method and Description |
---|---|
Path |
FileMergingCheckpointStateOutputStream.getFilePath() |
Modifier and Type | Class and Description |
---|---|
protected static class |
CopyOnWriteStateMap.StateMapEntry<K,N,S>
One entry in the
CopyOnWriteStateMap . |
Modifier and Type | Method and Description |
---|---|
LocalRecoveryConfig |
HeapKeyedStateBackend.getLocalRecoveryConfig() |
StateMap<K,N,S> |
StateTable.getMapForKeyGroup(int keyGroupIndex) |
StateMap<K,N,S>[] |
StateTable.getState()
Returns the internal data structure.
|
StateTable<K,N,SV> |
AbstractHeapState.getStateTable()
This should only be used for testing.
|
int |
HeapKeyedStateBackend.numKeyValueStateEntries()
Returns the total number of state entries across all keys/namespaces.
|
int |
HeapKeyedStateBackend.numKeyValueStateEntries(Object namespace)
Returns the total number of state entries across all keys for the given namespace.
|
int |
StateTable.sizeOfNamespace(Object namespace) |
abstract int |
StateMap.sizeOfNamespace(Object namespace) |
Modifier and Type | Field and Description |
---|---|
static int |
TaskManagerRunner.FAILURE_EXIT_CODE |
Modifier and Type | Method and Description |
---|---|
boolean |
DefaultJobLeaderService.containsJob(JobID jobId)
Check whether the service monitors the given job.
|
static ResourceProfile |
TaskExecutorResourceUtils.generateDefaultSlotResourceProfile(TaskExecutorResourceSpec taskExecutorResourceSpec,
int numberOfSlots)
|
static ResourceProfile |
TaskExecutorResourceUtils.generateTotalAvailableResourceProfile(TaskExecutorResourceSpec taskExecutorResourceSpec) |
static TaskExecutorResourceSpec |
TaskExecutorResourceUtils.resourceSpecFromConfigForLocalExecution(Configuration config) |
Modifier and Type | Method and Description |
---|---|
boolean |
TaskSlotTableImpl.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
Duration slotTimeout) |
boolean |
TaskSlotTable.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
Duration slotTimeout)
Allocate the slot with the given index for the given job and allocation id.
|
boolean |
TaskSlotTableImpl.isClosed() |
Modifier and Type | Class and Description |
---|---|
static class |
TaskManagerLocation.DefaultHostNameSupplier
This Supplier class could retrieve the FQDN host name of the given InetAddress on demand,
extract the pure host name and cache the results for later use.
|
static class |
TaskManagerLocation.IpOnlyHostNameSupplier
This Supplier class returns the IP address of the given InetAddress directly, therefore no
reverse DNS lookup is required.
|
Modifier and Type | Method and Description |
---|---|
static void |
Task.setupPartitionsAndGates(ResultPartitionWriter[] producedPartitions,
InputGate[] inputGates) |
Constructor and Description |
---|
TaskManagerLocation(ResourceID resourceID,
InetAddress inetAddress,
int dataPort)
Constructs a new instance connection info object.
|
TaskManagerLocation(ResourceID resourceID,
InetAddress inetAddress,
int dataPort,
TaskManagerLocation.HostNameSupplier hostNameSupplier,
String nodeId)
Constructs a new instance connection info object.
|
Modifier and Type | Field and Description |
---|---|
static String |
EnvironmentInformation.UNKNOWN_COMMIT_ID |
static String |
EnvironmentInformation.UNKNOWN_COMMIT_ID_ABBREV |
Modifier and Type | Method and Description |
---|---|
static CuratorFrameworkWithUnhandledErrorListener |
ZooKeeperUtils.startCuratorFramework(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFrameworkFactory.Builder builder,
FatalErrorHandler fatalErrorHandler)
Starts a
CuratorFramework instance and connects it to the given ZooKeeper quorum from
a builder. |
Constructor and Description |
---|
Factory(Duration cacheExpireTimeout,
int cacheSizeLimit,
org.apache.flink.shaded.guava31.com.google.common.base.Ticker ticker) |
Modifier and Type | Field and Description |
---|---|
static String |
BashJavaUtils.EXECUTION_PREFIX |
Constructor and Description |
---|
JobManagerFlinkMemory(MemorySize jvmHeap,
MemorySize offHeapMemory) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JarUploadResponseBody> |
JarUploadHandler.handleRequest(HandlerRequest<EmptyRequestBody> request,
RestfulGateway gateway) |
CompletableFuture<JarRunResponseBody> |
JarRunHandler.handleRequest(HandlerRequest<JarRunRequestBody> request,
DispatcherGateway gateway) |
Constructor and Description |
---|
JarPlanRequestBody() |
JarRunRequestBody(String entryClassName,
String programArguments,
List<String> programArgumentsList,
Integer parallelism,
JobID jobId,
Boolean allowNonRestoredState,
String savepointPath,
RestoreMode restoreMode,
Map<String,String> flinkConfiguration)
Fallback constructor ONLY for tests.
|
Modifier and Type | Method and Description |
---|---|
int |
TaskStatsRequestCoordinator.getNumberOfPendingRequests() |
Modifier and Type | Method and Description |
---|---|
protected void |
ZooKeeperStateHandleStore.setStateHandle(String path,
byte[] serializedStateHandle,
int expectedVersion) |
Modifier and Type | Method and Description |
---|---|
int |
ChangelogKeyedStateBackend.numKeyValueStateEntries() |
Modifier and Type | Field and Description |
---|---|
static String |
ChangelogMaterializationMetricGroup.COMPLETED_MATERIALIZATION |
static String |
ChangelogMaterializationMetricGroup.FAILED_MATERIALIZATION |
static String |
ChangelogMaterializationMetricGroup.LAST_DURATION_OF_MATERIALIZATION |
static String |
ChangelogMaterializationMetricGroup.STARTED_MATERIALIZATION |
Modifier and Type | Method and Description |
---|---|
void |
PeriodicMaterializationManager.triggerMaterialization() |
Modifier and Type | Method and Description |
---|---|
static long |
ForStMemoryControllerUtils.calculateActualCacheCapacity(long totalMemorySize,
double writeBufferRatio)
Calculate the actual memory capacity of cache, which would be shared among ForSt instance(s).
|
void |
ForStNativeMetricOptions.enableNativeStatistics(ConfigOption<Boolean> nativeStatisticsOption) |
Constructor and Description |
---|
ForStResourceContainer() |
ForStResourceContainer(ForStOptionsFactory optionsFactory) |
ForStResourceContainer(ForStOptionsFactory optionsFactory,
OpaqueMemoryResource<org.apache.flink.state.forst.ForStSharedResources> sharedResources) |
Modifier and Type | Class and Description |
---|---|
static class |
CoGroupedStreams.UnionSerializer<T1,T2>
|
Modifier and Type | Class and Description |
---|---|
static class |
TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>
Deprecated.
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
|
static class |
TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>
Deprecated.
Custom
TypeSerializer for the sink state. |
static class |
TwoPhaseCommitSinkFunction.TransactionHolder<TXN>
Deprecated.
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 |
Buckets.getMaxPartCounter() |
Bucket<IN,BucketID> |
Buckets.onElement(IN value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
long |
ContinuousFileMonitoringFunction.getGlobalModificationTime()
Deprecated.
|
TypeSerializer<T> |
FromElementsFunction.getSerializer()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static JobGraph |
StreamingJobGraphGenerator.createJobGraph(StreamGraph streamGraph) |
JobGraph |
StreamGraph.getJobGraph()
|
StreamOperator<?> |
StreamNode.getOperator() |
List<StreamEdge> |
StreamGraph.getStreamEdges(int sourceId) |
List<StreamEdge> |
StreamGraph.getStreamEdges(int sourceId,
int targetId) |
List<StreamEdge> |
StreamGraph.getStreamEdgesOrThrow(int sourceId,
int targetId)
Deprecated.
|
<T extends StreamOperator<?>> |
StreamConfig.getStreamOperator(ClassLoader cl) |
void |
StreamConfig.setAndSerializeTransitiveChainedTaskConfigs(Map<Integer,StreamConfig> chainedTaskConfigs) |
void |
StreamConfig.setStateBackendUsesManagedMemory(boolean usesManagedMemory) |
void |
StreamConfig.setStreamOperator(StreamOperator<?> operator) |
Constructor and Description |
---|
StreamNode(Integer id,
String slotSharingGroup,
String coLocationGroup,
StreamOperator<?> operator,
String operatorName,
Class<? extends TaskInvokable> jobVertexClass) |
Modifier and Type | Method and Description |
---|---|
boolean |
StreamSource.emitsProgressiveWatermarks()
Deprecated.
|
OperatorStateBackend |
AbstractStreamOperator.getOperatorStateBackend() |
OperatorStateBackend |
AbstractStreamOperatorV2.getOperatorStateBackend() |
ProcessingTimeService |
AbstractStreamOperator.getProcessingTimeService()
Returns the
ProcessingTimeService responsible for getting the current processing time
and registering timers. |
ProcessingTimeService |
AbstractStreamOperatorV2.getProcessingTimeService()
Returns the
ProcessingTimeService responsible for getting the current processing time
and registering timers. |
StreamingRuntimeContext |
AbstractStreamOperator.getRuntimeContext()
Returns a context that allows the operator to query information about the execution and also
to interact with systems such as broadcast variables and managed state.
|
SourceReader<OUT,SplitT> |
SourceOperator.getSourceReader() |
protected void |
SourceOperator.initSourceMetricGroup() |
int |
InternalTimerServiceImpl.numEventTimeTimers() |
int |
InternalTimeServiceManagerImpl.numEventTimeTimers() |
int |
InternalTimerServiceImpl.numEventTimeTimers(N namespace) |
int |
InternalTimerServiceImpl.numProcessingTimeTimers() |
int |
InternalTimeServiceManagerImpl.numProcessingTimeTimers() |
int |
InternalTimerServiceImpl.numProcessingTimeTimers(N namespace) |
Constructor and Description |
---|
StreamingRuntimeContext(AbstractStreamOperator<?> operator,
Environment env,
Map<String,Accumulator<?,?>> accumulators) |
Modifier and Type | Class and Description |
---|---|
static class |
IntervalJoinOperator.BufferEntry<T>
A container for elements put in the left/write buffer.
|
static class |
IntervalJoinOperator.BufferEntrySerializer<T>
A
serializer for the IntervalJoinOperator.BufferEntry . |
Modifier and Type | Method and Description |
---|---|
T |
IntervalJoinOperator.BufferEntry.getElement() |
boolean |
IntervalJoinOperator.BufferEntry.hasBeenJoined() |
Modifier and Type | Method and Description |
---|---|
static byte[] |
CollectSinkFunction.serializeAccumulatorResult(long offset,
String version,
long lastCheckpointedOffset,
List<byte[]> buffer) |
Constructor and Description |
---|
CollectResultIterator(AbstractCollectResultBuffer<T> buffer,
CompletableFuture<OperatorID> operatorIdFuture,
String accumulatorName,
int retryMillis) |
Constructor and Description |
---|
WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?> output) |
Modifier and Type | Field and Description |
---|---|
protected org.apache.beam.sdk.fn.data.FnDataReceiver<org.apache.beam.sdk.util.WindowedValue<byte[]>> |
BeamPythonFunctionRunner.mainInputReceiver
The receiver which forwards the input elements to a remote environment for processing.
|
protected LinkedBlockingQueue<Tuple2<String,byte[]>> |
BeamPythonFunctionRunner.resultBuffer
Buffers the Python function execution result which has still not been processed.
|
Modifier and Type | Method and Description |
---|---|
org.apache.beam.runners.fnexecution.control.JobBundleFactory |
BeamPythonFunctionRunner.createJobBundleFactory(org.apache.beam.vendor.grpc.v1p48p1.com.google.protobuf.Struct pipelineOptions) |
protected void |
BeamPythonFunctionRunner.startBundle() |
Modifier and Type | Method and Description |
---|---|
StreamSink<T> |
LegacySinkTransformation.getOperator() |
TwoInputStreamOperator<IN1,IN2,OUT> |
TwoInputTransformation.getOperator() |
StreamSource<T,?> |
LegacySourceTransformation.getOperator() |
OneInputStreamOperator<IN,OUT> |
OneInputTransformation.getOperator() |
Modifier and Type | Method and Description |
---|---|
long |
TimeEvictor.getWindowSize() |
Modifier and Type | Method and Description |
---|---|
long |
ContinuousProcessingTimeTrigger.getInterval() |
long |
ContinuousEventTimeTrigger.getInterval() |
Trigger<T,W> |
PurgingTrigger.getNestedTrigger() |
Modifier and Type | Interface and Description |
---|---|
interface |
UpstreamRecoveryTracker
Tracks status of upstream channels while they recover.
|
Modifier and Type | Method and Description |
---|---|
static SingleCheckpointBarrierHandler |
SingleCheckpointBarrierHandler.createUnalignedCheckpointBarrierHandler(SubtaskCheckpointCoordinator checkpointCoordinator,
String taskName,
CheckpointableTask toNotifyOnCheckpoint,
Clock clock,
boolean enableCheckpointsAfterTasksFinish,
CheckpointableInput... inputs) |
Modifier and Type | Method and Description |
---|---|
Sink<InputT> |
SinkWriterOperatorFactory.getSink() |
Modifier and Type | Field and Description |
---|---|
static int |
SinkV1CommittableDeserializer.MAGIC_NUMBER
It is important to keep this number consistent with the number used by the
StreamingCommitterStateSerializer in Flink 1.13 and 1.14. |
Modifier and Type | Method and Description |
---|---|
long |
WindowOperatorBuilder.getAllowedLateness() |
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 | Method and Description |
---|---|
static <OUT> RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> |
StreamTask.createRecordWriterDelegate(StreamConfig configuration,
Environment environment) |
Iterable<StreamOperatorWrapper<?,?>> |
OperatorChain.getAllOperators()
Returns an
Iterable which traverses all operators in forward topological order. |
boolean |
StreamTask.isMailboxLoopRunning() |
boolean |
StreamTask.runMailboxStep() |
boolean |
StreamTask.runSingleMailboxLoop() |
Constructor and Description |
---|
OneInputStreamTask(Environment env,
TimerService timeProvider)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
Modifier and Type | Method and Description |
---|---|
MailboxMetricsController |
MailboxProcessor.getMailboxMetricsControl()
Gets
MailboxMetricsController for control and access to mailbox metrics. |
boolean |
MailboxProcessor.isDefaultActionAvailable() |
boolean |
MailboxProcessor.isMailboxLoopRunning() |
void |
MailboxMetricsController.measureMailboxLatency() |
boolean |
MailboxProcessor.runMailboxStep()
Execute a single (as small as possible) step of the mailbox.
|
boolean |
MailboxProcessor.runSingleMailboxLoop()
Execute a single (as small as possible) step of the mailbox.
|
void |
MailboxMetricsController.setLatencyMeasurementInterval(int measurementInterval) |
Constructor and Description |
---|
MailboxProcessor() |
TaskMailboxImpl() |
Modifier and Type | Class and Description |
---|---|
protected static class |
StatusWatermarkValve.SubpartitionStatus
An
SubpartitionStatus keeps track of a subpartition's last watermark, stream status,
and whether or not the subpartition's current watermark is aligned with the overall watermark
output from the valve. |
Modifier and Type | Method and Description |
---|---|
protected StatusWatermarkValve.SubpartitionStatus |
StatusWatermarkValve.getSubpartitionStatus(int subpartitionIndex) |
Constructor and Description |
---|
StatusWatermarkValve(int numInputChannels)
Returns a new
StatusWatermarkValve . |
Modifier and Type | Method and Description |
---|---|
TableImpl |
TableEnvironmentImpl.createTable(QueryOperation tableOperation) |
Pipeline |
TableEnvironmentImpl.generatePipelineFromQueryOperation(QueryOperation operation,
List<Transformation<?>> transformations)
generate execution
Pipeline from QueryOperation . |
org.apache.flink.shaded.guava31.com.google.common.cache.CacheStats |
PlanCacheManager.getCacheStats() |
List<ModifyOperation> |
StatementSetImpl.getOperations() |
Planner |
TableEnvironmentImpl.getPlanner() |
Modifier and Type | Method and Description |
---|---|
List<CatalogModificationListener> |
CatalogManager.getCatalogModificationListeners() |
Constructor and Description |
---|
ConnectorCatalogTable(TableSource<T1> tableSource,
TableSink<T2> tableSink,
TableSchema tableSchema,
boolean isBatch) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hive.metastore.api.Database |
HiveCatalog.getHiveDatabase(String databaseName) |
org.apache.hadoop.hive.metastore.api.Partition |
HiveCatalog.getHivePartition(org.apache.hadoop.hive.metastore.api.Table hiveTable,
CatalogPartitionSpec partitionSpec) |
Modifier and Type | Method and Description |
---|---|
protected static void |
SqlClient.startClient(String[] args,
Supplier<org.jline.terminal.Terminal> terminalFactory) |
Constructor and Description |
---|
CliChangelogResultView(org.jline.terminal.Terminal terminal,
ResultDescriptor resultDescriptor,
ChangelogResult collectResult) |
CliClient(Supplier<org.jline.terminal.Terminal> terminalFactory,
Executor executor,
Path historyFilePath,
org.jline.reader.MaskingCallback inputTransformer)
Creates a CLI instance with a custom terminal.
|
CliTableauResultView(org.jline.terminal.Terminal terminal,
ResultDescriptor resultDescriptor,
ChangelogResult collectResult,
long queryBeginTime) |
CliTableResultView(org.jline.terminal.Terminal terminal,
ResultDescriptor resultDescriptor,
MaterializedResult materializedResult) |
Modifier and Type | Method and Description |
---|---|
SessionHandle |
ExecutorImpl.getSessionHandle() |
Constructor and Description |
---|
StatementResult(ResolvedSchema resultSchema,
CloseableIterator<RowData> resultProvider,
boolean isQueryResult,
ResultKind resultKind,
JobID jobID,
RowDataToStringConverter toStringConverter) |
Modifier and Type | Field and Description |
---|---|
protected static int |
ChangelogCollectResult.CHANGE_RECORD_BUFFER_SIZE |
Modifier and Type | Method and Description |
---|---|
protected List<RowData> |
MaterializedCollectResultBase.getMaterializedTable() |
Constructor and Description |
---|
MaterializedCollectBatchResult(StatementResult tableResult,
int maxRowCount,
int overcommitThreshold) |
MaterializedCollectStreamResult(StatementResult tableResult,
int maxRowCount,
int overcommitThreshold) |
Modifier and Type | Method and Description |
---|---|
Collection<RowData> |
DynamicFilteringData.getData() |
Constructor and Description |
---|
HiveServer2Endpoint(SqlGatewayService service,
InetSocketAddress socketAddress,
long maxMessageSize,
int requestTimeoutMs,
int backOffSlotLengthMs,
int minWorkerThreads,
int maxWorkerThreads,
Duration workerKeepAliveTime,
String catalogName,
HiveConf hiveConf,
String defaultDatabase,
String moduleName,
boolean allowEmbedded,
boolean isVerbose) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hive.service.rpc.thrift.TRowSet |
ThriftObjectConversions.toColumnBasedSet(List<LogicalType> fieldTypes,
List<RowData.FieldGetter> fieldGetters,
List<RowData> rows) |
static org.apache.hive.service.rpc.thrift.TRowSet |
ThriftObjectConversions.toRowBasedSet(List<LogicalType> fieldTypes,
List<RowData.FieldGetter> fieldGetters,
List<RowData> rows) |
Modifier and Type | Method and Description |
---|---|
String |
TestFileSystemCatalog.getCatalogPathStr() |
Modifier and Type | Method and Description |
---|---|
protected void |
HiveGenericUDTF.setCollector(org.apache.hadoop.hive.ql.udf.generic.Collector collector) |
Modifier and Type | Method and Description |
---|---|
EmbeddedQuartzScheduler |
SqlGatewayRestEndpoint.getQuartzScheduler() |
Constructor and Description |
---|
GetApiVersionHandler(SqlGatewayService service,
Map<String,String> responseHeaders,
MessageHeaders<EmptyRequestBody,GetApiVersionResponseBody,EmptyMessageParameters> messageHeaders,
List<SqlGatewayRestAPIVersion> stableVersions) |
Modifier and Type | Method and Description |
---|---|
Session |
SqlGatewayServiceImpl.getSession(SessionHandle sessionHandle) |
Modifier and Type | Method and Description |
---|---|
protected static String |
MaterializedTableManager.getInsertStatement(ObjectIdentifier materializedTableIdentifier,
String definitionQuery,
Map<String,String> dynamicOptions)
Generate insert statement for materialized table.
|
protected static String |
MaterializedTableManager.getRefreshStatement(ObjectIdentifier tableIdentifier,
String definitionQuery,
Map<String,String> partitionSpec,
Map<String,String> dynamicOptions) |
Modifier and Type | Class and Description |
---|---|
class |
OperationManager.Operation
Operation to manage the execution, results and so on.
|
Modifier and Type | Method and Description |
---|---|
OperationManager.Operation |
OperationManager.getOperation(OperationHandle operationHandle) |
int |
OperationManager.getOperationCount() |
Constructor and Description |
---|
OperationExecutor(SessionContext context,
Configuration executionConfig) |
Modifier and Type | Method and Description |
---|---|
ResultStore |
ResultFetcher.getResultStore() |
Modifier and Type | Method and Description |
---|---|
int |
SessionManagerImpl.currentSessionCount() |
int |
SessionManagerImpl.getOperationCount(SessionHandle sessionHandle) |
boolean |
SessionManagerImpl.isSessionAlive(SessionHandle sessionId) |
Modifier and Type | Method and Description |
---|---|
org.quartz.Scheduler |
EmbeddedQuartzScheduler.getQuartzScheduler() |
Constructor and Description |
---|
FlinkDatabaseMetaData(String url,
FlinkConnection connection,
Statement statement) |
Constructor and Description |
---|
HiveModule() |
HiveModule(String hiveVersion) |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
TruncateTableOperation.getTableIdentifier() |
Modifier and Type | Method and Description |
---|---|
Transformation<T> |
ExecNodeBase.getTransformation() |
static ExecNodeConfig |
ExecNodeConfig.ofTableConfig(TableConfig tableConfig,
boolean isCompiled) |
static void |
ExecNodeContext.resetIdCounter()
Reset the id counter to 0.
|
Modifier and Type | Method and Description |
---|---|
Optional<StreamExchangeMode> |
BatchExecExchange.getRequiredExchangeMode() |
ExecNode<?> |
BatchExecMultipleInput.getRootNode() |
Modifier and Type | Method and Description |
---|---|
static Tuple2<Pattern<RowData,RowData>,List<String>> |
CommonExecMatch.translatePattern(MatchSpec matchSpec,
ReadableConfig config,
ClassLoader classLoader,
RelBuilder relBuilder,
RowType inputRowType) |
Modifier and Type | Method and Description |
---|---|
static Map<String,ColumnStats> |
CatalogTableStatisticsConverter.convertToColumnStatsMap(Map<String,CatalogColumnStatisticsDataBase> columnStatisticsData) |
Modifier and Type | Method and Description |
---|---|
protected URL |
ResourceManager.getURLFromPath(Path path) |
Modifier and Type | Class and Description |
---|---|
static class |
LookupCacheManager.RefCountedCache
A wrapper class of
LookupCache which also tracks the reference count of it. |
Modifier and Type | Method and Description |
---|---|
LookupCache |
CachingLookupFunction.getCache() |
LookupCache |
CachingAsyncLookupFunction.getCache() |
Modifier and Type | Method and Description |
---|---|
List<org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner.JoinedRowResultFuture> |
AsyncLookupJoinRunner.getAllResultFutures() |
Constructor and Description |
---|
ResultRetryStrategy(AsyncRetryStrategy retryStrategy) |
Modifier and Type | Method and Description |
---|---|
int |
TableOperatorWrapper.getEndedInputCount() |
Modifier and Type | Method and Description |
---|---|
protected Counter |
AbstractRowTimeUnboundedPrecedingOver.getCounter() |
protected Counter |
RowTimeRangeBoundedPrecedingFunction.getCounter() |
protected Counter |
RowTimeRowsBoundedPrecedingFunction.getCounter() |
Modifier and Type | Field and Description |
---|---|
protected static String |
PythonStreamGroupAggregateOperator.STREAM_GROUP_AGGREGATE_URN |
protected static String |
PythonStreamGroupTableAggregateOperator.STREAM_GROUP_TABLE_AGGREGATE_URN |
Modifier and Type | Method and Description |
---|---|
void |
BinaryExternalSorter.write(MutableObjectIterator<BinaryRowData> iterator) |
Modifier and Type | Method and Description |
---|---|
Counter |
WindowAggOperator.getNumLateRecordsDropped() |
Gauge<Long> |
WindowAggOperator.getWatermarkLatency() |
Modifier and Type | Method and Description |
---|---|
Counter |
UnalignedWindowTableFunctionOperator.getNumLateRecordsDropped() |
Counter |
WindowTableFunctionOperatorBase.getNumNullRowTimeRecordsDropped() |
Gauge<Long> |
UnalignedWindowTableFunctionOperator.getWatermarkLatency() |
Modifier and Type | Method and Description |
---|---|
TypeSerializer |
ArrayDataSerializer.getEleSer() |
TypeSerializer |
MapDataSerializer.getKeySerializer() |
TypeSerializer |
MapDataSerializer.getValueSerializer() |
Modifier and Type | Method and Description |
---|---|
int |
AbstractAutoCloseableRegistry.getNumberOfRegisteredCloseables() |
boolean |
AbstractAutoCloseableRegistry.isCloseableRegistered(R c) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
YarnLogConfigUtil.setLogConfigFileInConfig(Configuration configuration,
String configurationDirectory) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.