TestPinotConfig.java

/*
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package com.facebook.presto.pinot;

import com.facebook.airlift.configuration.testing.ConfigAssertions;
import com.google.common.collect.ImmutableMap;
import io.airlift.units.Duration;
import org.testng.annotations.Test;

import java.util.Map;
import java.util.concurrent.TimeUnit;

import static com.facebook.presto.pinot.PinotConfig.DEFAULT_GRPC_TLS_STORE_TYPE;

public class TestPinotConfig
{
    @Test
    public void testDefaults()
    {
        ConfigAssertions.assertRecordedDefaults(
                ConfigAssertions.recordDefaults(PinotConfig.class)
                        .setExtraHttpHeaders("")
                        .setExtraGrpcMetadata("")
                        .setControllerUrls("")
                        .setLimitLargeForSegment(PinotConfig.DEFAULT_LIMIT_LARGE_FOR_SEGMENT)
                        .setTopNLarge(PinotConfig.DEFAULT_TOPN_LARGE)
                        .setEstimatedSizeInBytesForNonNumericColumn(20)
                        .setControllerRestService(null)
                        .setServiceHeaderParam("RPC-Service")
                        .setCallerHeaderValue("presto")
                        .setCallerHeaderParam("RPC-Caller")
                        .setOverrideDistinctCountFunction("distinctCount")
                        .setMetadataCacheExpiry(new Duration(2, TimeUnit.MINUTES))
                        .setInferDateTypeInSchema(true)
                        .setInferTimestampTypeInSchema(true)
                        .setForbidBrokerQueries(false)
                        .setRestProxyServiceForQuery(null)
                        .setUseProxy(false)
                        .setGrpcHost(null)
                        .setGrpcTlsKeyStoreType(DEFAULT_GRPC_TLS_STORE_TYPE)
                        .setGrpcTlsKeyStorePath(null)
                        .setGrpcTlsKeyStorePassword(null)
                        .setGrpcTlsTrustStoreType(DEFAULT_GRPC_TLS_STORE_TYPE)
                        .setGrpcTlsTrustStorePath(null)
                        .setGrpcTlsTrustStorePassword(null)
                        .setGrpcPort(PinotConfig.DEFAULT_PROXY_GRPC_PORT)
                        .setUseSecureConnection(false)
                        .setNumSegmentsPerSplit(1)
                        .setFetchRetryCount(2)
                        .setMarkDataFetchExceptionsAsRetriable(true)
                        .setPushdownTopNBrokerQueries(true)
                        .setPushdownProjectExpressions(true)
                        .setUseDateTrunc(false)
                        .setForbidSegmentQueries(false)
                        .setAttemptBrokerQueries(false)
                        .setStreamingServerGrpcMaxInboundMessageBytes(PinotConfig.DEFAULT_STREAMING_SERVER_GRPC_MAX_INBOUND_MESSAGE_BYTES)
                        .setNonAggregateLimitForBrokerQueries(PinotConfig.DEFAULT_NON_AGGREGATE_LIMIT_FOR_BROKER_QUERIES)
                        .setUseDateTrunc(false)
                        .setControllerAuthenticationType("NONE")
                        .setControllerAuthenticationUser(null)
                        .setControllerAuthenticationPassword(null)
                        .setBrokerAuthenticationType("NONE")
                        .setBrokerAuthenticationUser(null)
                        .setBrokerAuthenticationPassword(null)
                        .setQueryOptions(null));
    }

    @Test
    public void testExplicitPropertyMappings()
    {
        Map<String, String> properties = new ImmutableMap.Builder<String, String>()
                .put("pinot.extra-http-headers", "k:v")
                .put("pinot.extra-grpc-metadata", "k1:v1")
                .put("pinot.controller-rest-service", "pinot-controller-service")
                .put("pinot.controller-urls", "host1:1111,host2:1111")
                .put("pinot.topn-large", "1000")
                .put("pinot.estimated-size-in-bytes-for-non-numeric-column", "30")
                .put("pinot.metadata-expiry", "1m")
                .put("pinot.caller-header-value", "myCaller")
                .put("pinot.caller-header-param", "myParam")
                .put("pinot.service-header-param", "myServiceHeader")
                .put("pinot.infer-date-type-in-schema", "false")
                .put("pinot.infer-timestamp-type-in-schema", "false")
                .put("pinot.forbid-broker-queries", "true")
                .put("pinot.rest-proxy-service-for-query", "pinot-rest-proxy-service")
                .put("pinot.grpc-host", "localhost")
                .put("pinot.grpc-port", "8224")
                .put("pinot.proxy-enabled", "true")
                .put("pinot.num-segments-per-split", "2")
                .put("pinot.fetch-retry-count", "3")
                .put("pinot.mark-data-fetch-exceptions-as-retriable", "false")
                .put("pinot.non-aggregate-limit-for-broker-queries", "10")
                .put("pinot.use-date-trunc", "true")
                .put("pinot.limit-large-for-segment", "100")
                .put("pinot.pushdown-topn-broker-queries", "false")
                .put("pinot.pushdown-project-expressions", "false")
                .put("pinot.forbid-segment-queries", "true")
                .put("pinot.attempt-broker-queries", "true")
                .put("pinot.streaming-server-grpc-max-inbound-message-bytes", "65536")
                .put("pinot.secure-connection", "true")
                .put("pinot.override-distinct-count-function", "distinctCountBitmap")
                .put("pinot.grpc-tls-trust-store-password", "changeit1")
                .put("pinot.grpc-tls-trust-store-type", "jks-truststore")
                .put("pinot.grpc-tls-trust-store-path", "/path/to/truststore/file.jks")
                .put("pinot.grpc-tls-key-store-password", "changeit2")
                .put("pinot.grpc-tls-key-store-path", "/path/to/keystore/file.jks")
                .put("pinot.grpc-tls-key-store-type", "jks-keystore")
                .put("pinot.controller-authentication-type", "PASSWORD")
                .put("pinot.controller-authentication-user", "admin")
                .put("pinot.controller-authentication-password", "verysecret")
                .put("pinot.broker-authentication-type", "PASSWORD")
                .put("pinot.broker-authentication-user", "admin")
                .put("pinot.broker-authentication-password", "verysecret")
                .put("pinot.query-options", "enableNullHandling:true,skipUpsert:true")
                .build();

        PinotConfig expected = new PinotConfig()
                .setExtraHttpHeaders("k:v")
                .setExtraGrpcMetadata("k1:v1")
                .setControllerRestService("pinot-controller-service")
                .setControllerUrls("host1:1111,host2:1111")
                .setGrpcHost("localhost")
                .setGrpcPort(8224)
                .setLimitLargeForSegment(100000)
                .setTopNLarge(1000)
                .setEstimatedSizeInBytesForNonNumericColumn(30)
                .setServiceHeaderParam("myServiceHeader")
                .setCallerHeaderValue("myCaller")
                .setCallerHeaderParam("myParam")
                .setOverrideDistinctCountFunction("distinctCountBitmap")
                .setMetadataCacheExpiry(new Duration(1, TimeUnit.MINUTES))
                .setInferDateTypeInSchema(false)
                .setInferTimestampTypeInSchema(false)
                .setForbidBrokerQueries(true)
                .setRestProxyServiceForQuery("pinot-rest-proxy-service")
                .setNumSegmentsPerSplit(2)
                .setFetchRetryCount(3)
                .setMarkDataFetchExceptionsAsRetriable(false)
                .setNonAggregateLimitForBrokerQueries(10)
                .setLimitLargeForSegment(100)
                .setPushdownTopNBrokerQueries(false)
                .setPushdownProjectExpressions(false)
                .setForbidSegmentQueries(true)
                .setAttemptBrokerQueries(true)
                .setStreamingServerGrpcMaxInboundMessageBytes(65536)
                .setUseDateTrunc(true)
                .setUseProxy(true)
                .setGrpcTlsTrustStorePassword("changeit1")
                .setGrpcTlsTrustStoreType("jks-truststore")
                .setGrpcTlsTrustStorePath("/path/to/truststore/file.jks")
                .setGrpcTlsKeyStorePath("/path/to/keystore/file.jks")
                .setGrpcTlsKeyStorePassword("changeit2")
                .setGrpcTlsKeyStoreType("jks-keystore")
                .setControllerAuthenticationType("PASSWORD")
                .setControllerAuthenticationUser("admin")
                .setControllerAuthenticationPassword("verysecret")
                .setBrokerAuthenticationType("PASSWORD")
                .setBrokerAuthenticationUser("admin")
                .setBrokerAuthenticationPassword("verysecret")
                .setUseSecureConnection(true)
                .setQueryOptions("enableNullHandling:true,skipUpsert:true");

        ConfigAssertions.assertFullMapping(properties, expected);
    }
}