|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method private getTable(metastore ExtendedHiveMetastore, tableName SchemaTableName) : Table in class com.facebook.presto.hive.HivePartitionManager |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveMetadata(connectorId String, metastore ExtendedHiveMetastore, hdfsEnvironment HdfsEnvironment, partitionManager HivePartitionManager, timeZone DateTimeZone, allowCorruptWritesForTesting boolean, respectTableFormat boolean, bucketExecutionEnabled boolean, bucketWritingEnabled boolean, defaultStorageFormat HiveStorageFormat, typeManager TypeManager, locationService LocationService, tableParameterCodec TableParameterCodec, partitionUpdateCodec JsonCodec<PartitionUpdate>, renameExecutor Executor, typeTranslator TypeTranslator) in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public getTableDefaultLocation(user String, metastore ExtendedHiveMetastore, hdfsEnvironment HdfsEnvironment, schemaName String, tableName String) : Path in class com.facebook.presto.hive.HiveWriteUtils |
From |
To |
|
Change Parameter Type partition : Partition to partition : Optional<Partition> in method private getPartitionLocation(table Table, partition Optional<Partition>) : String in class com.facebook.presto.hive.BackgroundHiveSplitLoader |
From |
To |
|
Change Parameter Type hiveCluster : HiveCluster to delegate : ExtendedHiveMetastore in method public CachingHiveMetastore(delegate ExtendedHiveMetastore, executor ExecutorService, hiveClientConfig HiveClientConfig) in class com.facebook.presto.hive.metastore.CachingHiveMetastore |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method private writeTestFile(config HiveClientConfig, metastore ExtendedHiveMetastore, outputPath String) : long in class com.facebook.presto.hive.TestHivePageSink |
From |
To |
|
Change Parameter Type partition : Partition to partition : Optional<Partition> in method private getPartitionKeys(table Table, partition Optional<Partition>) : List<HivePartitionKey> in class com.facebook.presto.hive.BackgroundHiveSplitLoader |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveConnectorFactory(name String, optionalConfig Map<String,String>, classLoader ClassLoader, metastore ExtendedHiveMetastore, typeManager TypeManager, pageIndexerFactory PageIndexerFactory, nodeManager NodeManager) in class com.facebook.presto.hive.HiveConnectorFactory |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveSplitManager(connectorId HiveConnectorId, hiveClientConfig HiveClientConfig, metastore ExtendedHiveMetastore, namenodeStats NamenodeStats, hdfsEnvironment HdfsEnvironment, directoryLister DirectoryLister, executorService ExecutorService) in class com.facebook.presto.hive.HiveSplitManager |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public listAllDataPaths(metastore ExtendedHiveMetastore, schemaName String, tableName String) : List<String> in class com.facebook.presto.hive.AbstractTestHiveClient |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method private getDatabase(metastore ExtendedHiveMetastore, database String) : Database in class com.facebook.presto.hive.HiveWriteUtils |
From |
To |
|
Change Parameter Type partition : Partition to partition : Optional<Partition> in method package HivePartitionMetadata(hivePartition HivePartition, partition Optional<Partition>) in class com.facebook.presto.hive.HivePartitionMetadata |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public getPartitions(session ConnectorSession, metastore ExtendedHiveMetastore, tableHandle ConnectorTableHandle, effectivePredicate TupleDomain<ColumnHandle>) : HivePartitionResult in class com.facebook.presto.hive.HivePartitionManager |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveMetadataFactory(connectorId HiveConnectorId, metastore ExtendedHiveMetastore, hdfsEnvironment HdfsEnvironment, partitionManager HivePartitionManager, timeZone DateTimeZone, maxConcurrentFileRenames int, allowCorruptWritesForTesting boolean, respectTableFormat boolean, bucketExecutionEnabled boolean, bucketWritingEnabled boolean, defaultStorageFormat HiveStorageFormat, typeManager TypeManager, locationService LocationService, tableParameterCodec TableParameterCodec, partitionUpdateCodec JsonCodec<PartitionUpdate>, executorService ExecutorService, typeTranslator TypeTranslator) in class com.facebook.presto.hive.HiveMetadataFactory |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HivePlugin(name String, metastore ExtendedHiveMetastore) in class com.facebook.presto.hive.HivePlugin |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveLocationService(metastore ExtendedHiveMetastore, hdfsEnvironment HdfsEnvironment) in class com.facebook.presto.hive.HiveLocationService |
From |
To |
|
Change Parameter Type storageDescriptor : StorageDescriptor to storage : Storage in method private checkWritable(tableName SchemaTableName, partitionName Optional<String>, protectMode ProtectMode, parameters Map<String,String>, storage Storage) : void in class com.facebook.presto.hive.HiveWriteUtils |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public SqlStandardAccessControl(connectorId HiveConnectorId, metastore ExtendedHiveMetastore, hiveClientConfig HiveClientConfig) in class com.facebook.presto.hive.SqlStandardAccessControl |
From |
To |
|
Change Parameter Type table : Table to table : org.apache.hadoop.hive.metastore.api.Table in method public alterTable(databaseName String, tableName String, table org.apache.hadoop.hive.metastore.api.Table) : void in class com.facebook.presto.hive.metastore.ThriftHiveMetastore |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveMetadataFactory(connectorId HiveConnectorId, hiveClientConfig HiveClientConfig, metastore ExtendedHiveMetastore, hdfsEnvironment HdfsEnvironment, partitionManager HivePartitionManager, executorService ExecutorService, typeManager TypeManager, locationService LocationService, tableParameterCodec TableParameterCodec, partitionUpdateCodec JsonCodec<PartitionUpdate>, typeTranslator TypeTranslator) in class com.facebook.presto.hive.HiveMetadataFactory |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveSplitManager(connectorId HiveConnectorId, metastore ExtendedHiveMetastore, namenodeStats NamenodeStats, hdfsEnvironment HdfsEnvironment, directoryLister DirectoryLister, executor Executor, maxOutstandingSplits int, minPartitionBatchSize int, maxPartitionBatchSize int, maxInitialSplits int, recursiveDfsWalkerEnabled boolean) in class com.facebook.presto.hive.HiveSplitManager |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HivePageSinkProvider(hdfsEnvironment HdfsEnvironment, metastore ExtendedHiveMetastore, pageIndexerFactory PageIndexerFactory, typeManager TypeManager, config HiveClientConfig, locationService LocationService, partitionUpdateCodec JsonCodec<PartitionUpdate>) in class com.facebook.presto.hive.HivePageSinkProvider |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method private getFilteredPartitionNames(metastore ExtendedHiveMetastore, tableName SchemaTableName, partitionKeys List<HiveColumnHandle>, effectivePredicate TupleDomain<ColumnHandle>) : List<String> in class com.facebook.presto.hive.HivePartitionManager |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HiveClientModule(connectorId String, metastore ExtendedHiveMetastore, typeManager TypeManager, pageIndexerFactory PageIndexerFactory, nodeManager NodeManager) in class com.facebook.presto.hive.HiveClientModule |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public HivePageSink(schemaName String, tableName String, isCreateTable boolean, inputColumns List<HiveColumnHandle>, tableStorageFormat HiveStorageFormat, partitionStorageFormat HiveStorageFormat, locationHandle LocationHandle, locationService LocationService, filePrefix String, bucketProperty Optional<HiveBucketProperty>, metastore ExtendedHiveMetastore, pageIndexerFactory PageIndexerFactory, typeManager TypeManager, hdfsEnvironment HdfsEnvironment, maxOpenPartitions int, immutablePartitions boolean, compress boolean, partitionUpdateCodec JsonCodec<PartitionUpdate>, session ConnectorSession) in class com.facebook.presto.hive.HivePageSink |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method public PartitionCommitter(schemaName String, tableName String, metastore ExtendedHiveMetastore, batchSize int) in class com.facebook.presto.hive.HiveMetadata.PartitionCommitter |
From |
To |
|
Change Parameter Type metastore : HiveMetastore to metastore : ExtendedHiveMetastore in method private createPageSink(transaction HiveTransactionHandle, config HiveClientConfig, metastore ExtendedHiveMetastore, outputPath Path) : ConnectorPageSink in class com.facebook.presto.hive.TestHivePageSink |
From |
To |
|
Change Parameter Type hiveCluster : HiveCluster to delegate : ExtendedHiveMetastore in method public TestingHiveMetastore(delegate ExtendedHiveMetastore, executor ExecutorService, hiveClientConfig HiveClientConfig, writableBucket String, hdfsEnvironment HdfsEnvironment) in class com.facebook.presto.hive.AbstractTestHiveClientS3.TestingHiveMetastore |
From |
To |
|
Change Parameter Type hiveCluster : HiveCluster to delegate : ExtendedHiveMetastore in method public CachingHiveMetastore(delegate ExtendedHiveMetastore, executor ExecutorService, cacheTtl Duration, refreshInterval Duration) in class com.facebook.presto.hive.metastore.CachingHiveMetastore |
From |
To |
|
Change Variable Type builder : ImmutableMap.Builder<String,Partition> to builder : ImmutableList.Builder<Partition> in method public getPartitionsByNames(databaseName String, tableName String, partitionNames List<String>) : List<Partition> in class com.facebook.presto.hive.metastore.InMemoryHiveMetastore |
From |
To |
|
Change Variable Type type : String to type : HiveType in method private buildTableObject(schemaName String, tableName String, tableOwner String, columnHandles List<HiveColumnHandle>, hiveStorageFormat HiveStorageFormat, partitionedBy List<String>, bucketProperty Optional<HiveBucketProperty>, additionalTableParameters Map<String,String>, targetPath Path) : Table in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type partitionType : String to partitionType : HiveType in method private getPartitionMetadata(metastore ExtendedHiveMetastore, table Table, tableName SchemaTableName, hivePartitions List<HivePartition>, bucketProperty Optional<HiveBucketProperty>) : Iterable<HivePartitionMetadata> in class com.facebook.presto.hive.HiveSplitManager |
From |
To |
|
Change Variable Type descriptor : StorageDescriptor to storageFormat : StorageFormat in method private extractHiveStorageFormat(table Table) : HiveStorageFormat in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type batch : Optional<Map<String,Partition>> to batch : Map<String,Optional<Partition>> in method private getPartitionMetadata(metastore ExtendedHiveMetastore, table Table, tableName SchemaTableName, hivePartitions List<HivePartition>, bucketProperty Optional<HiveBucketProperty>) : Iterable<HivePartitionMetadata> in class com.facebook.presto.hive.HiveSplitManager |
From |
To |
|
Change Variable Type columns : ImmutableList.Builder<FieldSchema> to columns : ImmutableList.Builder<Column> in method private buildTableObject(schemaName String, tableName String, tableOwner String, columnHandles List<HiveColumnHandle>, hiveStorageFormat HiveStorageFormat, partitionedBy List<String>, bucketProperty Optional<HiveBucketProperty>, additionalTableParameters Map<String,String>, targetPath Path) : Table in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type field : FieldSchema to field : Column in method public getPartitionKeyColumnHandles(connectorId String, table Table) : List<HiveColumnHandle> in class com.facebook.presto.hive.HiveUtil |
From |
To |
|
Change Variable Type field : FieldSchema to field : Column in method private columnMetadataGetter(table Table, typeManager TypeManager) : Function<HiveColumnHandle,ColumnMetadata> in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type fieldSchema : FieldSchema to column : Column in method public beginInsert(session ConnectorSession, tableHandle ConnectorTableHandle) : HiveInsertTableHandle in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type field : FieldSchema to field : Column in method public getNonPartitionKeyColumnHandles(connectorId String, table Table) : List<HiveColumnHandle> in class com.facebook.presto.hive.HiveUtil |
From |
To |
|
Change Variable Type partitionColumns : List<FieldSchema> to partitionColumns : List<Column> in method private buildTableObject(schemaName String, tableName String, tableOwner String, columnHandles List<HiveColumnHandle>, hiveStorageFormat HiveStorageFormat, partitionedBy List<String>, bucketProperty Optional<HiveBucketProperty>, additionalTableParameters Map<String,String>, targetPath Path) : Table in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type tableType : String to tableType : HiveType in method private getPartitionMetadata(metastore ExtendedHiveMetastore, table Table, tableName SchemaTableName, hivePartitions List<HivePartition>, bucketProperty Optional<HiveBucketProperty>) : Iterable<HivePartitionMetadata> in class com.facebook.presto.hive.HiveSplitManager |
From |
To |
|
Change Variable Type partitionKeys : List<FieldSchema> to partitionKeys : List<Column> in method public getPartitionKeyColumnHandles(connectorId String, table Table) : List<HiveColumnHandle> in class com.facebook.presto.hive.HiveUtil |
From |
To |
|
Change Variable Type columnComment : Map<String,String> to columnComment : Map<String,Optional<String>> in method private columnMetadataGetter(table Table, typeManager TypeManager) : Function<HiveColumnHandle,ColumnMetadata> in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type keys : List<FieldSchema> to keys : List<Column> in method private getPartitionKeys(table Table, partition Optional<Partition>) : List<HivePartitionKey> in class com.facebook.presto.hive.BackgroundHiveSplitLoader |
From |
To |
|
Change Variable Type builder : ImmutableMap.Builder<String,String> to builder : ImmutableMap.Builder<String,Optional<String>> in method private columnMetadataGetter(table Table, typeManager TypeManager) : Function<HiveColumnHandle,ColumnMetadata> in class com.facebook.presto.hive.HiveMetadata |
From |
To |
|
Change Variable Type storageDescriptor : StorageDescriptor to storageFormat : StorageFormat in method private createWriter(partitionRow List<Object>, fileName String) : HiveRecordWriter in class com.facebook.presto.hive.HivePageSink |
From |
To |
|
Change Variable Type partitionsByName : ImmutableMap.Builder<String,Partition> to partitionsByName : ImmutableMap.Builder<String,Optional<Partition>> in method public getPartitionsByNames(databaseName String, tableName String, partitionNames List<String>) : Map<String,Optional<Partition>> in class com.facebook.presto.hive.metastore.CachingHiveMetastore |
From |
To |