You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pinot.apache.org by GitBox <gi...@apache.org> on 2019/05/21 06:09:16 UTC

[GitHub] [incubator-pinot] snleee edited a comment on issue #4228: Fixing log issue for pinot-tools package

snleee edited a comment on issue #4228: Fixing log issue for pinot-tools package
URL: https://github.com/apache/incubator-pinot/pull/4228#issuecomment-494252208
 
 
   Before change
   ```
   ❯ ~/workspace/pinot/pinot-tools/target/pinot-tools-pkg/bin/pinot-admin.sh
   ERROR StatusLogger File not found in file system or classpath: /Users/snlee/workspace/pinot/pinot-tools/target/pinot-tools-pkg/conf/pinot-admin-log4j2.xml
   ERROR StatusLogger Reconfiguration failed: No configuration found for '728938a9' at 'null' in 'null'
   ```
   
   
   After change
   ```
   ❯ ~/workspace/pinot/pinot-tools/target/pinot-tools-pkg/bin/pinot-admin.sh
   Usage: pinot-admin.sh <subCommand>
   Valid subCommands are:
   	GenerateData	<Generate random data as per the provided scema>
   	CreateSegment	<Create pinot segments from provided avro/csv/json input data.>
   	StartZookeeper	<Start the Zookeeper process at the specified port.>
   	StartKafka	<Start Kafka at the specified port.>
   	StreamAvroIntoKafka	<Stream the specified Avro file into a Kafka topic, which can be read by Pinot
   by using org.apache.pinot.core.realtime.impl.kafka.KafkaJSONMessageDecoder as the
   message decoder class name (stream.kafka.decoder.class.name).>
   	StartController	<Start the Pinot Controller Process at the specified port.>
   	StartBroker	<Start the Pinot Broker process at the specified port>
   	StartServer	<Start the Pinot Server process at the specified port.>
   	AddTable	<Add table specified in the json file, to the controller.>
   	ChangeTableState	<Change the state (enable|disable|drop) of Pinot table>
   	AddTenant	<Add tenant as per the specification provided.>
   	AddSchema	<Add schema specified in the schema file to the controller>
   	UploadSegment	<Upload the Pinot segments.>
   	PostQuery	<Query the uploaded Pinot segments.>
   	StopProcess	<Stop the specified processes.>
   	DeleteCluster	<Remove the Pinot Cluster from Helix.>
   	ShowClusterInfo	<Show Pinot Cluster information.>
   	AvroSchemaToPinotSchema	<Extracting Pinot schema file from Avro schema or data file.>
   	RebalanceTable	<Rebalance segments for a single table or all tables belonging to a tenant. This is run after adding new nodes to rebalance the segments>
   	ChangeNumReplicas	<Re-writes idealState to reflect the value of numReplicas in table config>
   	ValidateConfig	<Validate configs on the specified Zookeeper.>
   	VerifySegmentState	<Compares helix IdealState and ExternalView for specified table prefixes>
   	ConvertPinotSegment	<Convert Pinot segments to another format such as AVRO/CSV/JSON.>
   	MoveReplicaGroup	<Move complete set of segment replica from source servers to tagged servers in cluster>
   	BackfillSegmentColumn	<Backfill a column in segments of a pinot table, with a millis value corresponding to the time column>
   	VerifyClusterState	<Verify cluster's state after shutting down several nodes randomly.>
   	ApplyTableConfig	<Applies the given table configuration to a cluster.>
   	RealtimeProvisioningHelper	<Given the table config, partitions, retention and a sample completed segment for a realtime table to be setup, this tool will provide memory used by each host and an optimal segment size for various combinations of hours to consume and hosts>
   	MergeSegments	<Create the merged segment using concatenation>
   	CheckOfflineSegmentIntervals	<Prints out offline segments with invalid time intervals>
   For other crud operations, please refer to ${ControllerAddress}/help.
   ```

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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