You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pinot.apache.org by xi...@apache.org on 2020/05/10 12:16:01 UTC

[incubator-pinot] branch template_ingestion_spec updated (5d63269 -> 48033d1)

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

xiangfu pushed a change to branch template_ingestion_spec
in repository https://gitbox.apache.org/repos/asf/incubator-pinot.git.


 discard 5d63269  Adding template support for Pinot Ingestion Job Spec
     add 4c6050f  Move UpsertConfig under package org.apache.pinot.spi.config.table (#5311)
     add 6a1565c  Allow configuring minion task timeout in the PinotTaskGenerator (#5317)
     add 997853d  Use time column from table config instead of schema (#5320)
     add 26ae5ee  Adding missing presto quickstart examples (#5323)
     add c87be27  In SegmentPurger, use table config to generate the segment (#5325)
     add edef309  Adding helm repo index so user can use helm without checkout pinot repo. (#5327)
     add 2bda544  Timespec to datetimespec conversion utility (#5324)
     add f08d355  Fix the case-sensitibity handling for aggregation functions (#5329)
     add 0ccb389  Fix the bug introduced in #5132 where ScanBasedDocIdIterator.isMatch() is still required (#5328)
     add b500286  ReturnType in ConstantExecutionNode (#5334)
     add 31c55af  [Part 3.1] Deepstore by-pass: Add a new best effort segment uploader with bounded upload time and d… (#5314)
     add 52001be  Add transformFunction field in equals, hashCode and toJsonObject of FieldSpec (#5335)
     add 413cbe0  [TE] frontend - harleyjj/alert-details - remove separate time range for anomalies in alert-details component (#5340)
     add 347a97f  Add api in AggregationFunction to get compiled input expressions. (#5339)
     add f0ecdf1  Track unavailable segments in InstanceSelector (#5337)
     add bf4ed66  [SegmentGeneratorConfig Cleanup] Refactor CreateSegmentCommand and remove the clone constructor in SegmentGeneratorConfig (#5338)
     add 589b1aa  Fix new broker to old server backward compatibility issue. (#5342)
     add e46a92a  Change log level to info in pinot-tools (#5348)
     add bfd263a  Remove some unused TimeFieldSpec related methods from Schema (#5347)
     add 51f313d  [TE] update reporting anomaly endpoints (#5333)
     add aa0a5f1  Remove excessive SchemaBuilder#addTime methods (#5349)
     add 5cbdfcb  [SegmentGeneratorConfig Cleanup] Make PinotOutputFormat use table config and schema to create segments (#5350)
     add d0a87b5  Pass valid tableConfig to SegmentGeneratorConfig in all tests (#5353)
     add af5a901  Optimize RealtimeDictionaryBasedRangePredicateEvaluator by not scanning the dictionary when cardinality is high (#5331)
     add 9246d7e  Update package.json to resolve sharp version to fix the local build issue. (#5215)
     add 44b0a91  Fix NoSuchMethodError on ServerConfiguration.addHttpHandler (#5357)
     add 48033d1  Adding template support for Pinot Ingestion Job Spec

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   (5d63269)
            \
             N -- N -- N   refs/heads/template_ingestion_spec (48033d1)

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:
 .../pinot-presto/etc/catalog/pinot.properties      |  23 +-
 .../etc/catalog/pinot_quickstart.properties}       |  18 +-
 docker/images/pinot/Dockerfile                     |   4 +
 kubernetes/helm/index.yaml                         |  54 +++
 kubernetes/helm/pinot-0.2.0.tgz                    | Bin 0 -> 102559 bytes
 kubernetes/helm/values.yaml                        |   6 +-
 .../apache/pinot/broker/api/RequestStatistics.java |   9 +
 .../broker/api/resources/PinotBrokerDebug.java     |  15 +-
 .../requesthandler/BaseBrokerRequestHandler.java   | 100 +++---
 .../pinot/broker/routing/RoutingManager.java       |  30 +-
 .../apache/pinot/broker/routing/RoutingTable.java  |  29 +-
 .../instanceselector/BaseInstanceSelector.java     | 156 ++++++---
 .../routing/instanceselector/InstanceSelector.java |  29 +-
 .../routing/timeboundary/TimeBoundaryManager.java  |  17 +-
 .../broker/broker/HelixBrokerStarterTest.java      |  18 +-
 .../instanceselector/InstanceSelectorTest.java     | 218 ++++++++++--
 .../timeboundary/TimeBoundaryManagerTest.java      |   4 +-
 .../org/apache/pinot/common/utils/SchemaUtils.java |   3 +-
 .../common/utils/config/TableConfigUtils.java      |   2 +-
 .../parsers/PinotQuery2BrokerRequestConverter.java |   7 +
 .../pql/parsers/pql2/ast/FunctionCallAstNode.java  |   6 +
 .../apache/pinot/common/data/FieldSpecTest.java    |   9 +-
 .../org/apache/pinot/common/data/SchemaTest.java   |  83 +----
 .../common/utils/config/TableConfigSerDeTest.java  |  12 +-
 .../core/minion/PinotHelixTaskResourceManager.java |  13 +-
 .../helix/core/minion/PinotTaskManager.java        |   3 +-
 .../generator/ConvertToRawIndexTaskGenerator.java  |  16 +-
 .../core/minion/generator/PinotTaskGenerator.java  |  24 +-
 .../controller/util/AutoAddInvertedIndex.java      |  14 +-
 ...PinotInstanceAssignmentRestletResourceTest.java |   5 +-
 .../core/data/function/DateTimeFunctions.java      | 169 ++++++++-
 .../data/function/DefaultFunctionEvaluator.java    |  14 +-
 .../pinot/core/data/function/FunctionRegistry.java |  30 +-
 .../realtime/HLRealtimeSegmentDataManager.java     | 268 +++++++-------
 .../realtime/LLRealtimeSegmentDataManager.java     |   6 +-
 .../manager/realtime/PinotFSSegmentUploader.java   |  86 +++++
 .../manager/realtime/SegmentCommitterFactory.java  |  13 +-
 .../data/manager/realtime/SegmentUploader.java     |   3 +-
 .../realtime/Server2ControllerSegmentUploader.java |   3 +-
 .../manager/realtime/SplitSegmentCommitter.java    |  20 +-
 .../generator/SegmentGeneratorConfig.java          | 242 +++++--------
 .../immutable/ImmutableSegmentLoader.java          |   2 +-
 .../indexsegment/mutable/MutableSegmentImpl.java   |  45 ++-
 .../pinot/core/minion/RawIndexConverter.java       |  11 +-
 .../apache/pinot/core/minion/SegmentConverter.java |  41 ++-
 .../apache/pinot/core/minion/SegmentPurger.java    |  46 +--
 .../minion/rollup/MergeRollupSegmentConverter.java |  35 +-
 .../operator/dociditerators/AndDocIdIterator.java  |  11 +
 .../ExpressionScanDocIdIterator.java               | 111 +++---
 .../dociditerators/MVScanDocIdIterator.java        |  14 +-
 .../dociditerators/SVScanDocIdIterator.java        |  12 +-
 .../dociditerators/ScanBasedDocIdIterator.java     |   2 +
 .../BaseDictionaryBasedPredicateEvaluator.java     |   3 -
 .../BaseRawValueBasedPredicateEvaluator.java       |   2 -
 .../predicate/PredicateEvaluatorProvider.java      |   8 +-
 .../predicate/RangePredicateEvaluatorFactory.java  | 109 ++++--
 .../plan/AggregationGroupByOrderByPlanNode.java    |   5 +-
 .../core/plan/AggregationGroupByPlanNode.java      |   5 +-
 .../pinot/core/plan/AggregationPlanNode.java       |   6 +-
 .../apache/pinot/core/plan/SelectionPlanNode.java  |  40 ++-
 .../apache/pinot/core/plan/TransformPlanNode.java  |  94 +++--
 .../aggregation/function/AggregationFunction.java  |   8 +
 .../function/AggregationFunctionUtils.java         |  32 ++
 .../function/AvgAggregationFunction.java           |  14 +-
 .../function/CountAggregationFunction.java         |  11 +-
 .../function/CountMVAggregationFunction.java       |  14 +-
 .../function/DistinctAggregationFunction.java      |  17 +-
 .../function/DistinctCountAggregationFunction.java |  10 +
 .../DistinctCountHLLAggregationFunction.java       |  10 +
 .../DistinctCountRawHLLAggregationFunction.java    |  10 +
 .../function/FastHLLAggregationFunction.java       |  10 +
 .../function/MaxAggregationFunction.java           |  10 +
 .../function/MinAggregationFunction.java           |  11 +
 .../function/MinMaxRangeAggregationFunction.java   |  13 +-
 .../function/PercentileAggregationFunction.java    |   9 +
 .../function/PercentileEstAggregationFunction.java |  12 +-
 .../PercentileTDigestAggregationFunction.java      |   9 +
 .../function/SumAggregationFunction.java           |  10 +
 .../converter/RealtimeSegmentConverter.java        |  92 ++---
 .../ColumnMinMaxValueGenerator.java                |  35 +-
 .../apache/pinot/core/common/DataFetcherTest.java  |   7 +-
 .../function/DateTimeFunctionEvaluatorTest.java    | 127 ++++++-
 .../realtime/PinotFSSegmentUploaderTest.java       | 187 ++++++++++
 .../Server2ControllerSegmentUploaderTest.java      |   8 +-
 .../MultiplePinotSegmentRecordReaderTest.java      |  11 +-
 .../data/readers/PinotSegmentRecordReaderTest.java |  11 +-
 .../pinot/core/data/readers/PinotSegmentUtil.java  |   6 +-
 .../data/readers/RecordReaderSampleDataTest.java   |  97 +-----
 .../ExpressionTransformerTimeTest.java             |   4 +-
 .../generator/SegmentGeneratorConfigTest.java      |  40 ++-
 .../MutableSegmentImplAggregateMetricsTest.java    |   4 +-
 .../minion/MergeRollupSegmentConverterTest.java    |  12 +-
 .../pinot/core/minion/SegmentConverterTest.java    |  13 +-
 .../pinot/core/minion/SegmentPurgerTest.java       |  25 +-
 .../function/BaseTransformFunctionTest.java        |   7 +-
 .../function/DateTruncTransformFunctionTest.java   |   7 +-
 ...adataAndDictionaryAggregationPlanMakerTest.java |  12 +-
 ...ngeOfflineDictionaryPredicateEvaluatorTest.java |  31 +-
 .../segment/index/creator/RawIndexCreatorTest.java |  11 +-
 .../SegmentGenerationWithBytesTypeTest.java        |  12 +-
 .../SegmentGenerationWithNullValueVectorTest.java  |  10 +-
 .../SegmentGenerationWithTimeColumnTest.java       |  22 +-
 .../index/creator/SegmentPartitionTest.java        |   6 +-
 .../index/loader/SegmentPreProcessorTest.java      |   8 +-
 .../pinot/core/startree/v2/BaseStarTreeV2Test.java |   6 +-
 .../apache/pinot/core/util/SchemaUtilsTest.java    |   2 +-
 .../pinot/queries/BaseMultiValueQueriesTest.java   |  11 +-
 .../pinot/queries/BaseSingleValueQueriesTest.java  |  11 +-
 .../apache/pinot/queries/DistinctQueriesTest.java  |   5 +-
 .../apache/pinot/queries/FastHllQueriesTest.java   |  11 +-
 .../queries/PercentileTDigestMVQueriesTest.java    |   6 +-
 .../queries/PercentileTDigestQueriesTest.java      |   6 +-
 .../RangePredicateWithSortedInvertedIndexTest.java |  12 +-
 .../pinot/queries/SerializedBytesQueriesTest.java  |   7 +-
 .../pinot/queries/TextSearchQueriesTest.java       |   7 +-
 .../apache/pinot/queries/TransformQueriesTest.java |  22 +-
 .../DefaultAggregationExecutorTest.java            |   9 +-
 .../DictionaryBasedGroupKeyGeneratorTest.java      |  28 +-
 .../groupby/NoDictionaryGroupKeyGeneratorTest.java |  26 +-
 .../converter/RealtimeSegmentConverterTest.java    |   9 +-
 .../v1/creator/OnHeapDictionariesTest.java         |  11 +-
 .../segments/v1/creator/SegmentTestUtils.java      |  75 +---
 .../tests/BaseClusterIntegrationTest.java          |  15 +-
 .../tests/BaseClusterIntegrationTestSet.java       |   4 +-
 .../pinot/integration/tests/ClusterTest.java       |  78 ++---
 .../ControllerPeriodicTasksIntegrationTests.java   |  18 +-
 ...vertToRawIndexMinionClusterIntegrationTest.java |  12 +-
 .../DefaultCommitterRealtimeIntegrationTest.java   |  12 +-
 .../tests/HybridClusterIntegrationTest.java        |  31 +-
 ...ridClusterIntegrationTestCommandLineRunner.java |  10 +-
 .../LuceneRealtimeClusterIntegrationTest.java      |   2 +-
 .../tests/SimpleMinionClusterIntegrationTest.java  |  29 +-
 .../apache/pinot/server/util/SegmentTestUtils.java |  15 +-
 pinot-minion/pom.xml                               |   5 +
 .../org/apache/pinot/minion/MinionContext.java     |  12 +-
 .../org/apache/pinot/minion/MinionStarter.java     |  45 +--
 .../minion/events/DefaultMinionEventObserver.java  |   9 +-
 .../events/EventObserverFactoryRegistry.java       |   6 +-
 .../pinot/minion/events/MinionEventObserver.java   |   9 +-
 .../BaseSingleSegmentConversionExecutor.java       |  42 +--
 .../executor/ConvertToRawIndexTaskExecutor.java    |   6 +-
 .../pinot/minion/executor/PinotTaskExecutor.java   |  11 +-
 .../pinot/minion/executor/PurgeTaskExecutor.java   |  14 +-
 .../minion/executor/PurgeTaskExecutorTest.java     |  33 +-
 .../org/apache/pinot/perf/RawIndexBenchmark.java   |   7 +-
 .../pinot/perf/StringDictionaryPerfTest.java       |   6 +-
 .../batch/common/SegmentGenerationTaskRunner.java  |  23 +-
 ...ecordSerialization.java => FieldExtractor.java} |  26 +-
 .../pinot/hadoop/io/JsonBasedFieldExtractor.java}  |  33 +-
 .../pinot/hadoop/io/JsonPinotOutputFormat.java     |  99 ------
 .../apache/pinot/hadoop/io/PinotOutputFormat.java  | 146 +++-----
 .../org/apache/pinot/hadoop/io/PinotRecord.java    |  83 -----
 .../apache/pinot/hadoop/io/PinotRecordWriter.java  | 135 ++++---
 .../hadoop/job/HadoopSegmentPreprocessingJob.java  |  19 +-
 .../hadoop/job/mappers/SegmentCreationMapper.java  |  20 +-
 .../pinot/hadoop/io/PinotOutputFormatTest.java     | 184 ++++------
 .../spark/jobs/SparkSegmentCreationFunction.java   |  18 +-
 .../avro/AvroRecordToPinotRowGeneratorTest.java    |   5 +-
 .../plugin/inputformat/avro/AvroUtilsTest.java     |   3 +-
 .../stream/kafka/KafkaJSONMessageDecoderTest.java  |  47 ++-
 .../SegmentsValidationAndRetentionConfig.java      |   4 +-
 .../apache/pinot/spi/config/table/TableConfig.java |   3 -
 .../pinot/spi/config/{ => table}/UpsertConfig.java |  38 +-
 .../apache/pinot/spi/data/DateTimeFieldSpec.java   |  16 +-
 .../java/org/apache/pinot/spi/data/FieldSpec.java  |   8 +-
 .../java/org/apache/pinot/spi/data/Schema.java     | 264 +++++++++-----
 .../spi/utils/builder/TableConfigBuilder.java      |  11 +-
 .../apache/pinot/spi/config/UpsertConfigTest.java  |  72 ----
 .../spi/config/{ => table}/IndexingConfigTest.java |   6 +-
 .../spi/config/{ => table}/QuotaConfigTest.java    |   4 +-
 .../pinot/spi/config/table/UpsertConfigTest.java   |  72 ++++
 .../spi/config/{api => tenant}/TenantTest.java     |   5 +-
 .../pinot/spi/data/DateTimeFieldSpecUtilsTest.java | 188 ++++++++++
 pinot-tools/pom.xml                                |  15 +
 .../tools/admin/command/CreateSegmentCommand.java  | 386 +++++++--------------
 .../tools/admin/command/GenerateDataCommand.java   |   3 +-
 .../tools/query/comparison/ClusterStarter.java     |   4 +-
 .../segment/converter/SegmentMergeCommand.java     |  18 +-
 pinot-tools/src/main/resources/log4j2.xml          |   2 +-
 pom.xml                                            |  18 +-
 .../app/pods/components/alert-details/component.js |  24 +-
 .../dashboard/resources/v2/ResourceUtils.java      |   2 +-
 .../thirdeye/detection/DetectionResource.java      |  41 ++-
 website/package.json                               |   3 +
 184 files changed, 3688 insertions(+), 2453 deletions(-)
 copy website/scripts/build-site.sh => docker/images/pinot-presto/etc/catalog/pinot.properties (72%)
 mode change 100755 => 100644
 copy docker/images/{pinot-thirdeye/docker-build-and-push.sh => pinot-presto/etc/catalog/pinot_quickstart.properties} (72%)
 mode change 100755 => 100644
 create mode 100644 kubernetes/helm/index.yaml
 create mode 100644 kubernetes/helm/pinot-0.2.0.tgz
 copy thirdeye/thirdeye-pinot/src/main/java/org/apache/pinot/thirdeye/rootcause/impl/RCAConfiguration.java => pinot-broker/src/main/java/org/apache/pinot/broker/routing/RoutingTable.java (55%)
 create mode 100644 pinot-core/src/main/java/org/apache/pinot/core/data/manager/realtime/PinotFSSegmentUploader.java
 create mode 100644 pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/PinotFSSegmentUploaderTest.java
 rename pinot-plugins/pinot-batch-ingestion/v0_deprecated/pinot-hadoop/src/main/java/org/apache/pinot/hadoop/io/{PinotRecordSerialization.java => FieldExtractor.java} (66%)
 copy pinot-plugins/{pinot-input-format/pinot-avro-base/src/main/java/org/apache/pinot/plugin/inputformat/avro/AvroRecordExtractor.java => pinot-batch-ingestion/v0_deprecated/pinot-hadoop/src/main/java/org/apache/pinot/hadoop/io/JsonBasedFieldExtractor.java} (51%)
 delete mode 100644 pinot-plugins/pinot-batch-ingestion/v0_deprecated/pinot-hadoop/src/main/java/org/apache/pinot/hadoop/io/JsonPinotOutputFormat.java
 delete mode 100644 pinot-plugins/pinot-batch-ingestion/v0_deprecated/pinot-hadoop/src/main/java/org/apache/pinot/hadoop/io/PinotRecord.java
 rename pinot-spi/src/main/java/org/apache/pinot/spi/config/{ => table}/UpsertConfig.java (62%)
 delete mode 100644 pinot-spi/src/test/java/org/apache/pinot/spi/config/UpsertConfigTest.java
 rename pinot-spi/src/test/java/org/apache/pinot/spi/config/{ => table}/IndexingConfigTest.java (95%)
 rename pinot-spi/src/test/java/org/apache/pinot/spi/config/{ => table}/QuotaConfigTest.java (97%)
 create mode 100644 pinot-spi/src/test/java/org/apache/pinot/spi/config/table/UpsertConfigTest.java
 rename pinot-spi/src/test/java/org/apache/pinot/spi/config/{api => tenant}/TenantTest.java (91%)
 create mode 100644 pinot-spi/src/test/java/org/apache/pinot/spi/data/DateTimeFieldSpecUtilsTest.java


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