You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pinot.apache.org by jl...@apache.org on 2022/06/21 17:22:51 UTC

[pinot] branch helix-1.0 updated (3892ac340a -> 719125067a)

This is an automated email from the ASF dual-hosted git repository.

jlli pushed a change to branch helix-1.0
in repository https://gitbox.apache.org/repos/asf/pinot.git


    omit 3892ac340a Upgrade Helix to 1.0.4
     add d437d3a804 Extract one interface for Pinot Controller API protocol (#8852)
     add 7024a6d5e3 DataTable V4 implementation with per-column null bitmaps (#8872)
     add 52bf09dcf7 use storage.createFrom instead of copies in for-loop by hand (#8918)
     add dd1894d549 fix integration test (#8915)
     add b791cd10fe Prevent over allocating for group-by reduce (#8921)
     add e159846ecc properly shutdown query client with await termination (#8922)
     add 40848084e8 Remove disabled partitions when instance starts (#8920)
     add 4548783928 Optimize dictionary lookup for IN clause (#8891)
     add 5b5072663e Fix pulsar close bug (#8913)
     add 0bb9b5f27f use single string dict and eliminate the integer key field (#8894)
     add 7fef95ebe6 Reduce the heap memory usage for segment creation (#8846)
     add eb5835fed9 Shade org.apache.avro package for pinot plugins (#8916)
     add 517b8813b8 For dedup/partial-upsert, check all segments loaded when creating the consuming segment (#8923)
     add 09fcdd59cc Add metric for out-of-order partial-upsert events (#8925)
     add c77c73137e reuse created outputFormat (#8938)
     add 5b2b4aab82 Adding minion stateless k8s deployment for minion and by default turn off minion statefulset deployment. (#8936)
     add 9464359324 avoid redundant record transforms (#8935)
     add 291ed91797 reduce positioning operation to single operation (#8926)
     add 2644f48e7c Use binary search for index creation dictionary lookup (#8924)
     add 8474baee80 Optimize dateTimeConvert scalar function to only parse the format once (#8939)
     add adab6e1a44 Add replica group based instance assigment algorithm with FD awareness  (#8434)
     add 719125067a Upgrade Helix to 1.0.4

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (3892ac340a)
            \
             N -- N -- N   refs/heads/helix-1.0 (719125067a)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

No new revisions were added by this update.

Summary of changes:
 kubernetes/helm/pinot/requirements.lock            |   6 +-
 kubernetes/helm/pinot/requirements.yaml            |   2 +-
 kubernetes/helm/pinot/templates/_helpers.tpl       |  33 +
 .../{minion => minion-stateless}/configmap.yaml    |  14 +-
 .../templates/minion-stateless/deployment.yml      | 121 +++
 .../configmap.yaml => minion-stateless/pvc.yaml}   |  28 +-
 .../helm/pinot/templates/minion/configmap.yaml     |   2 +
 .../pinot/templates/minion/service-headless.yaml   |   2 +
 .../helm/pinot/templates/minion/service.yaml       |   2 +
 .../helm/pinot/templates/minion/statefulset.yml    |   2 +
 kubernetes/helm/pinot/values.yaml                  |  72 +-
 .../broker/broker/helix/BaseBrokerStarter.java     |   7 +-
 .../requesthandler/GrpcBrokerRequestHandler.java   |   7 +
 .../common/function/scalar/DateTimeConvert.java    |  80 ++
 .../common/function/scalar/DateTimeFunctions.java  |  48 --
 .../apache/pinot/common/metrics/ServerMeter.java   |   1 +
 .../request/context/predicate/BaseInPredicate.java | 158 ++++
 .../request/context/predicate/InPredicate.java     |  10 +-
 .../request/context/predicate/NotInPredicate.java  |  10 +-
 .../org/apache/pinot/common/utils/DataTable.java   |   3 +
 .../pinot/common/utils/grpc/GrpcQueryClient.java   |  15 +-
 .../pinot/common/utils/helix/HelixHelper.java      |  13 +
 .../pinot/common/utils/helix/HelixHelperTest.java  |  15 +-
 .../connector/spark/connector/PinotUtilsTest.scala |   8 +-
 .../pinot/controller/BaseControllerStarter.java    |   5 +-
 .../api/resources/PinotBrokerRestletResource.java  | 135 +---
 .../api/services/PinotBrokerService.java           | 217 ++++++
 .../helix/core/PinotHelixResourceManager.java      |   2 +
 .../instance/FDAwareInstancePartitionSelector.java | 457 ++++++++++++
 .../instance/InstanceAssignmentDriver.java         |   8 +-
 .../instance/InstancePartitionSelector.java        |  46 ++
 .../instance/InstancePartitionSelectorFactory.java |  48 ++
 .../InstanceReplicaGroupPartitionSelector.java     |  10 +-
 .../instance/InstanceAssignmentTest.java           | 809 +++++++++++++++++++++
 .../apache/pinot/core/common/ObjectSerDeUtils.java |  10 +-
 .../pinot/core/common/datablock/BaseDataBlock.java | 126 ++--
 .../core/common/datablock/ColumnarDataBlock.java   |  20 +-
 .../core/common/datablock/DataBlockBuilder.java    | 115 +--
 .../pinot/core/common/datablock/MetadataBlock.java |   9 +-
 .../pinot/core/common/datablock/RowDataBlock.java  |  45 +-
 .../pinot/core/common/datatable/BaseDataTable.java |  31 +-
 .../common/datatable/BaseDataTableBuilder.java     | 162 +++++
 .../core/common/datatable/DataTableBuilder.java    | 317 ++------
 .../common/datatable/DataTableBuilderV2V3.java     | 118 +++
 .../core/common/datatable/DataTableBuilderV4.java  |  90 +++
 .../core/common/datatable/DataTableFactory.java    |  55 +-
 .../core/common/datatable/DataTableImplV2.java     |   4 +-
 .../core/common/datatable/DataTableImplV3.java     |   4 +-
 .../core/common/datatable/DataTableImplV4.java     |   9 +-
 .../core/common/datatable/DataTableUtils.java      |  56 +-
 .../manager/realtime/RealtimeTableDataManager.java | 181 ++---
 .../StreamingInstanceResponseOperator.java         |   4 +-
 .../operator/blocks/IntermediateResultsBlock.java  |   8 +-
 .../predicate/InPredicateEvaluatorFactory.java     |  84 ++-
 .../predicate/NotInPredicateEvaluatorFactory.java  |  84 ++-
 .../operator/filter/predicate/PredicateUtils.java  |  88 +++
 .../pinot/core/query/distinct/DistinctTable.java   |   3 +-
 .../query/executor/ServerQueryExecutorV1Impl.java  |  11 +-
 .../core/query/reduce/GroupByDataTableReducer.java |  32 +-
 .../pinot/core/query/scheduler/QueryScheduler.java |   6 +-
 .../query/selection/SelectionOperatorUtils.java    |   4 +-
 .../framework/SegmentProcessorFramework.java       |   5 +-
 .../core/transport/InstanceRequestHandler.java     |  10 +-
 .../pinot/core/common/datablock/DataBlockTest.java |   6 +-
 .../core/common/datatable/DataTableSerDeTest.java  | 119 +--
 .../core/data/function/DateTimeFunctionsTest.java  |  34 +-
 .../core/query/reduce/BrokerReduceServiceTest.java |   3 +-
 .../query/scheduler/PrioritySchedulerTest.java     |   3 +-
 .../pinot/core/transport/QueryRoutingTest.java     |   8 +-
 pinot-distribution/pom.xml                         |   2 +-
 .../tests/GrpcBrokerClusterIntegrationTest.java    |  15 +
 .../tests/MultiStageEngineIntegrationTest.java     |   6 +-
 .../tests/OfflineGRPCServerIntegrationTest.java    |  15 +
 .../org/apache/pinot/minion/BaseMinionStarter.java |   1 +
 .../pinot/perf/BenchmarkDictionaryCreation.java    |  29 +-
 .../apache/pinot/plugin/filesystem/GcsPinotFS.java |  19 +-
 .../PulsarPartitionLevelConnectionHandler.java     |   9 +-
 pinot-plugins/pom.xml                              |   6 +-
 .../query/runtime/operator/HashJoinOperator.java   |   2 +-
 .../runtime/operator/MailboxSendOperator.java      |   2 +-
 .../pinot/query/runtime/QueryRunnerTest.java       |   3 +
 .../local/dedup/PartitionDedupMetadataManager.java |  73 +-
 .../local/dedup/TableDedupMetadataManager.java     |   9 +-
 .../converter/RealtimeSegmentConverter.java        |   4 +-
 .../BigDecimalOffHeapMutableDictionary.java        |   5 +
 .../BigDecimalOnHeapMutableDictionary.java         |   5 +
 .../dictionary/BytesOffHeapMutableDictionary.java  |   5 +
 .../dictionary/BytesOnHeapMutableDictionary.java   |   5 +
 .../dictionary/DoubleOffHeapMutableDictionary.java |   5 +
 .../dictionary/DoubleOnHeapMutableDictionary.java  |   5 +
 .../dictionary/FloatOffHeapMutableDictionary.java  |   5 +
 .../dictionary/FloatOnHeapMutableDictionary.java   |   5 +
 .../dictionary/IntOffHeapMutableDictionary.java    |   5 +
 .../dictionary/IntOnHeapMutableDictionary.java     |   5 +
 .../dictionary/LongOffHeapMutableDictionary.java   |   5 +
 .../dictionary/LongOnHeapMutableDictionary.java    |   5 +
 .../RecordReaderSegmentCreationDataSource.java     |   9 +-
 .../local/segment/creator/TransformPipeline.java   |   7 +
 .../creator/impl/SegmentColumnarIndexCreator.java  |  14 +-
 .../creator/impl/SegmentDictionaryCreator.java     | 228 +++---
 .../impl/SegmentIndexCreationDriverImpl.java       |  20 +-
 .../stats/AbstractColumnStatisticsCollector.java   |  61 +-
 .../BigDecimalColumnPreIndexStatsCollector.java    |  16 +-
 .../stats/BytesColumnPredIndexStatsCollector.java  |  14 +-
 .../stats/DoubleColumnPreIndexStatsCollector.java  |  22 +-
 .../stats/FloatColumnPreIndexStatsCollector.java   |  22 +-
 .../stats/IntColumnPreIndexStatsCollector.java     |  22 +-
 .../stats/LongColumnPreIndexStatsCollector.java    |  22 +-
 .../stats/SegmentPreIndexStatsCollectorImpl.java   |   4 +-
 .../stats/StringColumnPreIndexStatsCollector.java  |  16 +-
 .../DefaultNullValueVirtualColumnProvider.java     |   4 +
 .../index/column/PhysicalColumnIndexContainer.java |  25 +-
 .../defaultcolumn/BaseDefaultColumnHandler.java    |   9 +-
 .../index/readers/BaseImmutableDictionary.java     |   2 +-
 .../index/readers/BigDecimalDictionary.java        |  15 +-
 .../segment/index/readers/BytesDictionary.java     |   5 +
 ...java => ConstantValueBigDecimalDictionary.java} |  55 +-
 .../readers/ConstantValueBytesDictionary.java      |  11 +
 .../readers/ConstantValueDoubleDictionary.java     |  10 +
 .../readers/ConstantValueFloatDictionary.java      |  10 +
 .../index/readers/ConstantValueIntDictionary.java  |  10 +
 .../index/readers/ConstantValueLongDictionary.java |  10 +
 .../readers/ConstantValueStringDictionary.java     |   5 +
 .../segment/index/readers/DoubleDictionary.java    |   8 +-
 .../segment/index/readers/FloatDictionary.java     |   8 +-
 .../local/segment/index/readers/IntDictionary.java |   8 +-
 .../segment/index/readers/LongDictionary.java      |   8 +-
 ...ionary.java => OnHeapBigDecimalDictionary.java} |  50 +-
 ...sDictionary.java => OnHeapBytesDictionary.java} |  50 +-
 .../segment/index/readers/OnHeapDictionary.java    |  32 -
 .../index/readers/OnHeapDoubleDictionary.java      |  21 +-
 .../index/readers/OnHeapFloatDictionary.java       |  21 +-
 .../segment/index/readers/OnHeapIntDictionary.java |  21 +-
 .../index/readers/OnHeapLongDictionary.java        |  21 +-
 .../index/readers/OnHeapStringDictionary.java      |  22 +-
 .../segment/index/readers/StringDictionary.java    |   8 +-
 .../segment/local/upsert/PartialUpsertHandler.java |  29 +-
 .../upsert/PartitionUpsertMetadataManager.java     |  35 +-
 .../local/upsert/TableUpsertMetadataManager.java   |   4 +
 .../local/utils/tablestate/TableStateUtils.java    |  18 +-
 .../dedup/PartitionDedupMetadataManagerTest.java   | 109 +--
 .../mutable/MutableSegmentDedupeTest.java          |  19 +-
 .../local/segment/creator/DictionariesTest.java    |  22 +-
 .../index/readers/ImmutableDictionaryTest.java     | 123 ++--
 .../ImmutableDictionaryTypeConversionTest.java     | 127 ++--
 .../local/upsert/PartialUpsertHandlerTest.java     |  16 +-
 .../pinot/segment/spi/index/reader/Dictionary.java |  49 +-
 .../server/starter/helix/BaseServerStarter.java    |   7 +-
 .../table/assignment/InstanceAssignmentConfig.java |  21 +-
 .../java/org/apache/pinot/spi/utils/ByteArray.java |  45 +-
 .../admin/command/DataImportDryRunCommand.java     |   5 -
 151 files changed, 4269 insertions(+), 1801 deletions(-)
 copy kubernetes/helm/pinot/templates/{minion => minion-stateless}/configmap.yaml (70%)
 create mode 100644 kubernetes/helm/pinot/templates/minion-stateless/deployment.yml
 copy kubernetes/helm/pinot/templates/{broker/configmap.yaml => minion-stateless/pvc.yaml} (57%)
 create mode 100644 pinot-common/src/main/java/org/apache/pinot/common/function/scalar/DateTimeConvert.java
 create mode 100644 pinot-common/src/main/java/org/apache/pinot/common/request/context/predicate/BaseInPredicate.java
 create mode 100644 pinot-controller/src/main/java/org/apache/pinot/controller/api/services/PinotBrokerService.java
 create mode 100644 pinot-controller/src/main/java/org/apache/pinot/controller/helix/core/assignment/instance/FDAwareInstancePartitionSelector.java
 create mode 100644 pinot-controller/src/main/java/org/apache/pinot/controller/helix/core/assignment/instance/InstancePartitionSelector.java
 create mode 100644 pinot-controller/src/main/java/org/apache/pinot/controller/helix/core/assignment/instance/InstancePartitionSelectorFactory.java
 create mode 100644 pinot-core/src/main/java/org/apache/pinot/core/common/datatable/BaseDataTableBuilder.java
 create mode 100644 pinot-core/src/main/java/org/apache/pinot/core/common/datatable/DataTableBuilderV2V3.java
 create mode 100644 pinot-core/src/main/java/org/apache/pinot/core/common/datatable/DataTableBuilderV4.java
 copy pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/index/readers/{ConstantValueStringDictionary.java => ConstantValueBigDecimalDictionary.java} (62%)
 copy pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/index/readers/{BigDecimalDictionary.java => OnHeapBigDecimalDictionary.java} (55%)
 copy pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/index/readers/{BytesDictionary.java => OnHeapBytesDictionary.java} (55%)
 delete mode 100644 pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/index/readers/OnHeapDictionary.java


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@pinot.apache.org
For additional commands, e-mail: commits-help@pinot.apache.org